2025.10.15 20:15:05.887076 [ 409 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.15 20:15:05.888870 [ 409 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.15 20:15:06.487076 [ 409 ] {} 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.15 20:15:06.495828 [ 409 ] {} 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.15 20:15:13.208542 [ 409 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.10.15 20:15:13.224344 [ 409 ] {} KeeperLogStore: Removing all changelogs 2025.10.15 20:15:13.241643 [ 409 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.15 20:15:13.264356 [ 409 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.15 20:15:13.265466 [ 409 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.15 20:15:13.327918 [ 1035 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.15 20:15:14.419026 [ 409 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.10.15 20:15:14.436917 [ 409 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.10.15 20:15:15.129784 [ 409 ] {} 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.15 20:15:20.293803 [ 412 ] {b9553bd9-e848-4431-9c7a-07a3d15de0e3} 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.15 20:15:35.380204 [ 412 ] {d22198a4-9ca0-4a44-a20d-57d8eadb0a80} 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.15 20:15:50.248449 [ 1037 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.10.15 20:15:56.808821 [ 1300 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.15 20:15:56.810294 [ 1300 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.15 20:15:57.497806 [ 1300 ] {} 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.15 20:15:57.510079 [ 1300 ] {} 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.15 20:16:05.896441 [ 1300 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.15 20:16:05.920485 [ 1300 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.15 20:16:05.921656 [ 1300 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.15 20:16:05.986085 [ 1937 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.15 20:16:17.101708 [ 1300 ] {} 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.15 20:17:16.898182 [ 1303 ] {49d9e870-4aac-438f-81ce-719394ae4a50} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1212672 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 12409.16875, avg_chars_size = 14881.4025, limit = 10): (while reading column ParsedParams.Key2): (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 20 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40504) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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>&&) @ 0x000000001adfe6bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfce3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad30b85 9. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c122f9 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 @ 0x0000000027aa3a5b 11. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::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 @ 0x0000000027b79078 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027abdbc1 13. ./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) @ 0x000000002c80c27e 14. ./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>>&) @ 0x000000002c80afed 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de76ab4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007fdc903d6ac3 2025.10.15 20:17:32.229679 [ 1303 ] {49d9e870-4aac-438f-81ce-719394ae4a50} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1212672 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 12409.16875, avg_chars_size = 14881.4025, limit = 10): (while reading column ParsedParams.Key2): (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 20 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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>&&) @ 0x000000001adfe6bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfce3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad30b85 9. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c122f9 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 @ 0x0000000027aa3a5b 11. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::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 @ 0x0000000027b79078 12. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027abdbc1 13. ./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) @ 0x000000002c80c27e 14. ./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>>&) @ 0x000000002c80afed 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 19. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de76ab4 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007fdc903d6ac3 2025.10.15 20:17:58.312863 [ 1303 ] {d67b6207-9ba1-487e-ac9b-0721487cbc05} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.19 GiB (attempt to allocate chunk of 20130699 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39362) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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>&&) @ 0x000000001adfe6bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfce3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 8. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ad313ff 9. ./src/Common/PODArray.h:0: DB::ColumnString::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002af3c71f 10. ./contrib/llvm-project/libcxx/include/vector:1491: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000296e1203 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000296dfedb 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000029369189 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007fdc903d6ac3 25. ? @ 0x00007fdc90468850 2025.10.15 20:18:10.890969 [ 1303 ] {d67b6207-9ba1-487e-ac9b-0721487cbc05} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.19 GiB (attempt to allocate chunk of 20130699 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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>&&) @ 0x000000001adfe6bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfce3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 8. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ad313ff 9. ./src/Common/PODArray.h:0: DB::ColumnString::prepareForSquashing(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x000000002af3c71f 10. ./contrib/llvm-project/libcxx/include/vector:1491: DB::Squashing::squash(std::vector>&&, DB::CollectionOfDerivedItems&&) @ 0x00000000296e1203 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Squashing::squash(DB::Chunk&&) @ 0x00000000296dfedb 12. ./src/Processors/Transforms/ApplySquashingTransform.h:35: DB::ApplySquashingTransform::onConsume(DB::Chunk) @ 0x0000000029369189 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007fdc903d6ac3 25. ? @ 0x00007fdc90468850 2025.10.15 20:19:08.579360 [ 2761 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.15 20:19:08.581318 [ 2761 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.15 20:19:09.142729 [ 2761 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.15 20:19:09.145536 [ 2761 ] {} 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.15 20:19:09.154426 [ 2761 ] {} 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.15 20:19:17.812245 [ 2761 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.15 20:19:17.920086 [ 2761 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.15 20:19:17.921264 [ 2761 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.15 20:19:18.026958 [ 3400 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.15 20:19:28.972813 [ 2761 ] {} 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.15 20:19:32.289265 [ 2764 ] {e74e508f-2ccf-437a-a0f5-0f251e7ced74} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35294) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:19:32.292000 [ 2764 ] {e74e508f-2ccf-437a-a0f5-0f251e7ced74} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:19:38.768396 [ 2766 ] {efd54eb8-0a68-4454-bb9f-e4b07c0d4478} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49314) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:19:38.786358 [ 2766 ] {efd54eb8-0a68-4454-bb9f-e4b07c0d4478} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:39.879878 [ 2766 ] {670120c7-7c59-465e-aff6-0e320c4801ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49344) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 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&)>) @ 0x0000000029b44a70 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:39.892452 [ 2766 ] {670120c7-7c59-465e-aff6-0e320c4801ad} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 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&)>) @ 0x0000000029b44a70 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:41.999643 [ 3715 ] {c2c35ead-43f7-4688-a2bd-51b06d604d4c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49590) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 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&)>) @ 0x0000000029b44a70 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:42.009971 [ 3715 ] {c2c35ead-43f7-4688-a2bd-51b06d604d4c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 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&)>) @ 0x0000000029b44a70 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:42.411812 [ 3445 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_1_51_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:42.530055 [ 3740 ] {afc3d153-9cec-4752-9dee-fb6781244b86} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49640) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:19:42.534857 [ 3740 ] {afc3d153-9cec-4752-9dee-fb6781244b86} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:43.484749 [ 2766 ] {3ae3c30e-6195-47e7-afa9-4d834da9efbe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49738) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:19:43.495320 [ 2766 ] {3ae3c30e-6195-47e7-afa9-4d834da9efbe} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:43.916429 [ 3723 ] {8b9fa786-8c67-45ab-bfee-5f757cf186a7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49808) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:19:43.924329 [ 3723 ] {8b9fa786-8c67-45ab-bfee-5f757cf186a7} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:45.853900 [ 3752 ] {b4c38601-317a-43b3-ae25-656ad5d6f4ed} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41382) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 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&)>) @ 0x0000000029b44a70 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:45.869755 [ 3752 ] {b4c38601-317a-43b3-ae25-656ad5d6f4ed} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 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&)>) @ 0x0000000029b44a70 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:46.396594 [ 3888 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=740, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286a3bfd 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:131: DB::DDLWorker::startup() @ 0x000000002867573c 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&) @ 0x0000000027d8c9e3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b225edb 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:46.486610 [ 3740 ] {7e2c07c2-b78d-443f-8961-ca6dfa53008c} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_9pk7kgxb' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=740, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286a3bfd 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:131: DB::DDLWorker::startup() @ 0x000000002867573c 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&) @ 0x0000000027d8c9e3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b225edb 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10521.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41426) (comment: 00012_sorting_distributed.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9pk7kgxb ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000001b21ff93 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000001b1aaebc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192d35 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:19:46.490397 [ 3740 ] {7e2c07c2-b78d-443f-8961-ca6dfa53008c} DynamicQueryHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_9pk7kgxb' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=740, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286a3bfd 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:131: DB::DDLWorker::startup() @ 0x000000002867573c 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&) @ 0x0000000027d8c9e3 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b225edb 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10521.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000001b21ff93 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000001b1aaebc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192d35 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:46.915176 [ 3932 ] {15ce38a2-a098-42c1-9807-4b1203cbc2f5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:c196ca53-e9be-4281-864b-a0cf0a564aab'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41500) (comment: 00171_grouping_aggregated_transform_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rafb05q1 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:46.920701 [ 3932 ] {15ce38a2-a098-42c1-9807-4b1203cbc2f5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:c196ca53-e9be-4281-864b-a0cf0a564aab'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:47.082449 [ 3769 ] {e6115c56-7d40-41ec-942e-b154d18e5333} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:366daf24-0399-425c-8c82-658cddcc9763'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41562) (comment: 00170_s3_cache.sql) (in query: CREATE DATABASE IF NOT EXISTS test_vgipy10b ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:47.087629 [ 3769 ] {e6115c56-7d40-41ec-942e-b154d18e5333} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:366daf24-0399-425c-8c82-658cddcc9763'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:47.292341 [ 3740 ] {cfdde324-3a87-4af2-945c-3d1b109b00b1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:08284f93-7ed0-42ce-9281-54c9275cbdb6'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41590) (comment: 00159_parallel_formatting_tsv_and_friends.sh) (in query: CREATE DATABASE IF NOT EXISTS test_5qwv3kks ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:47.299590 [ 3740 ] {cfdde324-3a87-4af2-945c-3d1b109b00b1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:08284f93-7ed0-42ce-9281-54c9275cbdb6'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:47.520752 [ 2766 ] {36074c24-fb88-4bd8-950b-31b8128e97b1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:0a8d7221-9791-453f-a392-155123f2e394'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41614) (comment: 00007_uniq.sql) (in query: CREATE DATABASE IF NOT EXISTS test_esd8vocl ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:47.541419 [ 2766 ] {36074c24-fb88-4bd8-950b-31b8128e97b1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:0a8d7221-9791-453f-a392-155123f2e394'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:47.746931 [ 3740 ] {4bd48e3c-dde9-4f12-a7d4-96307c541146} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:20f81549-68c3-45a0-b79d-5b8aee9cf3da'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41660) (comment: 00177_memory_bound_merging.sh) (in query: CREATE DATABASE IF NOT EXISTS test_rff71963 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:47.762564 [ 3740 ] {4bd48e3c-dde9-4f12-a7d4-96307c541146} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:20f81549-68c3-45a0-b79d-5b8aee9cf3da'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:48.020775 [ 3769 ] {11c386ab-baf4-4411-ae42-06163ad68513} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:eb5b8bc3-3146-4a6a-bc7b-12eb36edda3e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41668) (comment: 00043_any_left_join.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lwokpc17 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:48.026905 [ 3769 ] {11c386ab-baf4-4411-ae42-06163ad68513} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:eb5b8bc3-3146-4a6a-bc7b-12eb36edda3e'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:48.255072 [ 3932 ] {4035a407-1111-4f67-8086-4077f8fea9d7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:aaba54e6-9ff7-4dd4-b31b-1bd8159e784f'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41686) (comment: 00172_early_constant_folding.sql) (in query: CREATE DATABASE IF NOT EXISTS test_k3wlcz1x ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:48.265088 [ 3932 ] {4035a407-1111-4f67-8086-4077f8fea9d7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:aaba54e6-9ff7-4dd4-b31b-1bd8159e784f'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:48.530463 [ 3908 ] {d1eb384e-577f-4f79-9bbf-63e5717d65d5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:be75fa1d-24ed-4949-bdc5-9686bd2a9a74'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41696) (comment: 00072_compare_date_and_string_index.sql) (in query: CREATE DATABASE IF NOT EXISTS test_db5bv6jz ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:48.547094 [ 3908 ] {d1eb384e-577f-4f79-9bbf-63e5717d65d5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:be75fa1d-24ed-4949-bdc5-9686bd2a9a74'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:48.834411 [ 3752 ] {7385ec9b-ea10-4bfd-8ca0-caf119cca6c0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:5c21810a-f0ba-49a0-9e03-6741d1267edc'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41710) (comment: 00088_global_in_one_shard_and_rows_before_limit.sql) (in query: CREATE DATABASE IF NOT EXISTS test_heonwanj ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:48.844285 [ 3752 ] {7385ec9b-ea10-4bfd-8ca0-caf119cca6c0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:5c21810a-f0ba-49a0-9e03-6741d1267edc'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:49.165295 [ 3932 ] {4ea5eb2f-bea0-4a7e-afff-e16f94bcfdde} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:faa0c305-c0a4-422b-9984-5e675a98bcd4'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41730) (comment: 00071_merge_tree_optimize_aio.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xs2m1ld4 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:49.182668 [ 3932 ] {4ea5eb2f-bea0-4a7e-afff-e16f94bcfdde} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:faa0c305-c0a4-422b-9984-5e675a98bcd4'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:49.362602 [ 3908 ] {52ba8853-d4d4-4644-80ee-a21ed7bf7bc5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:ff557079-9a66-440f-bd63-3d0cfd9a2ef3'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41748) (comment: 00159_parallel_formatting_json_and_friends_1.sh) (in query: CREATE DATABASE IF NOT EXISTS test_k5h2h8ie ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:49.378357 [ 3908 ] {52ba8853-d4d4-4644-80ee-a21ed7bf7bc5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:ff557079-9a66-440f-bd63-3d0cfd9a2ef3'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:49.522683 [ 3932 ] {797f1c87-7b2d-4164-9a2d-90032b72137b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:90f006d0-0042-4879-8afd-d14a6100dff3'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41760) (comment: 00086_array_reduce.sql) (in query: CREATE DATABASE IF NOT EXISTS test_q5xvte57 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:49.528027 [ 3932 ] {797f1c87-7b2d-4164-9a2d-90032b72137b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:90f006d0-0042-4879-8afd-d14a6100dff3'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:49.869685 [ 3908 ] {257fc651-9437-4dcc-a9f2-858cc48d9eb1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:ee912ae6-3c44-456a-883a-a2186b924882'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41776) (comment: 00093_prewhere_array_join.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i6xr6j4s ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:49.879297 [ 3908 ] {257fc651-9437-4dcc-a9f2-858cc48d9eb1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:ee912ae6-3c44-456a-883a-a2186b924882'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:50.065915 [ 3932 ] {89b024b5-a601-4e46-997f-2c7bcfcae42b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:cba1c034-4956-42c4-ac73-ca93f9d50b50'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41790) (comment: 00167_read_bytes_from_fs.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hvpncude ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:50.069787 [ 3932 ] {89b024b5-a601-4e46-997f-2c7bcfcae42b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:cba1c034-4956-42c4-ac73-ca93f9d50b50'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:50.333086 [ 3908 ] {3b335e01-b63b-4699-9962-fb7c173a834a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:230b5521-2458-4e12-9b8b-ef5f13ebb026'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41794) (comment: 00152_insert_different_granularity.sql) (in query: CREATE DATABASE IF NOT EXISTS test_yubmf00e ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:50.336166 [ 3908 ] {3b335e01-b63b-4699-9962-fb7c173a834a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:230b5521-2458-4e12-9b8b-ef5f13ebb026'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:50.488015 [ 3932 ] {ef3f77a6-99ec-44a8-991f-7e25da7d6e4a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:00567df6-9bc8-4aaf-b409-3b2cc102e841'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41804) (comment: 00142_system_columns.sql) (in query: CREATE DATABASE IF NOT EXISTS test_41zme1fx ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:50.491675 [ 3932 ] {ef3f77a6-99ec-44a8-991f-7e25da7d6e4a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:00567df6-9bc8-4aaf-b409-3b2cc102e841'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:50.648074 [ 2766 ] {db761634-e7c3-4625-8a14-be23f1909be2} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:f06f56d4-3051-4c28-991d-08dee9a8623a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41820) (comment: 00041_aggregating_materialized_view.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3cs75c4k ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:50.654170 [ 2766 ] {db761634-e7c3-4625-8a14-be23f1909be2} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:f06f56d4-3051-4c28-991d-08dee9a8623a'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:50.895443 [ 3896 ] {6dc45f0b-aa08-4d32-a624-96ced3636a0d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:271c21aa-5a28-4a04-bbc9-a1527c92456f'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41830) (comment: 00151_order_by_read_in_order.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0qz6y3af ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:50.918635 [ 3896 ] {6dc45f0b-aa08-4d32-a624-96ced3636a0d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:271c21aa-5a28-4a04-bbc9-a1527c92456f'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:51.146467 [ 2766 ] {8de7dae7-fb53-4e5d-8d44-eca43f69e52d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:cbbfd874-6aff-4ade-a17e-ead2039d7895'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41840) (comment: 00022_merge_prewhere.sql) (in query: CREATE DATABASE IF NOT EXISTS test_gvrf2b40 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:19:51.163848 [ 2766 ] {8de7dae7-fb53-4e5d-8d44-eca43f69e52d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '0f9f9688f62c:9000:192ed771-25a3-4277-a1cc-ee25f275d917', current host ID: '0f9f9688f62c:9000:cbbfd874-6aff-4ade-a17e-ead2039d7895'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&) @ 0x0000000027d8f455 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d47294 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:19:56.905771 [ 3896 ] {243f2e61-ca6b-4bce-a85f-f11832cee6e1} executeQuery: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6b83 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:56.930663 [ 3896 ] {243f2e61-ca6b-4bce-a85f-f11832cee6e1} TCPHandler: Code: 36. DB::Exception: extractGroups length of 'needle' argument must be greater than 0.: In scope SELECT extractGroups('hello', ''). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6b83 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:57.127462 [ 3896 ] {3ee412fa-0ad9-40b0-985b-7547e562f76a} executeQuery: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3ecf 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:57.135111 [ 3896 ] {3ee412fa-0ad9-40b0-985b-7547e562f76a} TCPHandler: Code: 36. DB::Exception: Length of 'needle' argument must be greater than 0.: In scope SELECT extractAllGroups('hello', ''). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3ecf 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:57.601054 [ 3896 ] {3e959c8a-04ae-4213-aa92-4cd2f239c96c} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6c28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:57.608208 [ 3896 ] {3e959c8a-04ae-4213-aa92-4cd2f239c96c} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', ' '). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6c28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:57.633275 [ 3752 ] {53ee337f-d444-4b95-b296-e0118686537e} executeQuery: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45800) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:19:57.717108 [ 3752 ] {53ee337f-d444-4b95-b296-e0118686537e} TCPHandler: Code: 57. DB::Exception: Table test_13.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:19:57.792748 [ 3896 ] {4529becf-b165-4639-90ae-e7805a9606e6} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', ' ');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3f71 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:57.805059 [ 3896 ] {4529becf-b165-4639-90ae-e7805a9606e6} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', ' '). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3f71 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:58.014858 [ 3896 ] {3fbf5ea3-40d6-4eaa-bb97-e4c4481ea3c5} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', '\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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6c28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:58.032174 [ 3896 ] {3fbf5ea3-40d6-4eaa-bb97-e4c4481ea3c5} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractGroups('hello', '\0'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6c28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:58.207675 [ 3896 ] {97951394-3046-4fe4-bb72-890e06f75645} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', '\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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3f71 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:58.226346 [ 3896 ] {97951394-3046-4fe4-bb72-890e06f75645} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: : In scope SELECT extractAllGroups('hello', '\0'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3f71 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:58.406322 [ 3896 ] {a1d89067-56cb-4b35-adc2-8b0159ad9796} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6c28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:58.415105 [ 3896 ] {a1d89067-56cb-4b35-adc2-8b0159ad9796} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractGroups('hello', 'world'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6c28 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:58.713021 [ 3896 ] {fb596638-0d3e-4e83-9bbf-6cf24ef15a2c} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3f71 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:58.716294 [ 3896 ] {fb596638-0d3e-4e83-9bbf-6cf24ef15a2c} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: world: In scope SELECT extractAllGroups('hello', 'world'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc3f71 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:58.946835 [ 3896 ] {db41a469-4d53-4be8-8d9f-de9d27f9c8da} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractGroups('hello', '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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6cca 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:58.957353 [ 3896 ] {db41a469-4d53-4be8-8d9f-de9d27f9c8da} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractGroups('hello', 'hello|world'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::(anonymous namespace)::FunctionExtractGroups::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc6cca 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:19:59.492940 [ 3896 ] {e156a087-d8aa-4653-91fe-9d54fe7cf946} executeQuery: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45790) (comment: 01275_extract_groups_check.sql) (in query: SELECT extractAllGroups('hello', '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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc4013 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:59.498728 [ 3896 ] {e156a087-d8aa-4653-91fe-9d54fe7cf946} TCPHandler: Code: 36. DB::Exception: There are no groups in regexp: hello|world: In scope SELECT extractAllGroups('hello', 'hello|world'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. DB::FunctionExtractAllGroups<(anonymous namespace)::VerticalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fcc4013 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:19:59.729931 [ 3769 ] {3e718006-0d9c-41e2-8937-b563985bbb7e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=23). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39356) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:19:59.736361 [ 3769 ] {3e718006-0d9c-41e2-8937-b563985bbb7e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=23). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:20:02.262436 [ 3769 ] {e4085fdf-3c84-4ff5-bcd1-17c109f745bc} executeQuery: Code: 57. DB::Exception: Table test_13.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45870) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:02.279471 [ 3769 ] {e4085fdf-3c84-4ff5-bcd1-17c109f745bc} TCPHandler: Code: 57. DB::Exception: Table test_13.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:06.754988 [ 3752 ] {5a7d0b4d-fd31-453e-88e4-d59058284c22} executeQuery: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (UNSUPPORTED_METHOD) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45846) (comment: 02343_analyzer_lambdas.sql) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT arrayMap(x -> compound_value.*, [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b5835fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3323: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a0cf9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:20:06.761258 [ 3752 ] {5a7d0b4d-fd31-453e-88e4-d59058284c22} TCPHandler: Code: 1. DB::Exception: Lambda as function argument resolved as list node with size 2. Expected 1. In scope x -> compound_value.*. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000b5835fa 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3323: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a0cf9 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:20:07.916361 [ 3752 ] {7e3d6e4c-31b9-4946-8b8a-c728875b1c7a} executeQuery: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (UNSUPPORTED_METHOD) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45846) (comment: 02343_analyzer_lambdas.sql) (in query: WITH cast(tuple(1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY x -> compound_value.* FROM test_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&, String&&) @ 0x00000000283c9266 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2247: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283aebfe 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b87a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:20:07.982526 [ 3752 ] {7e3d6e4c-31b9-4946-8b8a-c728875b1c7a} TCPHandler: Code: 1. DB::Exception: APPLY transformer APPLY x -> compound_value.* resolved as list node with size 2. Expected 1. In scope WITH CAST((1, 1), 'Tuple (value_1 UInt64, value_2 UInt64)') AS compound_value SELECT id, test_table.* APPLY (x -> compound_value.*) FROM test_table. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&, String&&) @ 0x00000000283c9266 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2247: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283aebfe 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b87a 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:20:09.070480 [ 3752 ] {02e35119-943f-4416-bcc9-c2018973fbca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=742, jobs=718). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45846) (comment: 02343_analyzer_lambdas.sql) (in query: SELECT 'Lambda carrying';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:09.078433 [ 3752 ] {02e35119-943f-4416-bcc9-c2018973fbca} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=742, jobs=718). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:09.913799 [ 3906 ] {343db327-3168-4d2a-8fd9-6c5d41aa065d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34608) (comment: 02343_analyzer_lambdas.sql) (in query: DROP DATABASE IF EXISTS test_78gi861n ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:20:09.922638 [ 3906 ] {343db327-3168-4d2a-8fd9-6c5d41aa065d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:10.121471 [ 3769 ] {d080299c-e4f9-4bc0-b619-53ec292b2982} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34624) (comment: 02343_analyzer_lambdas.sql) (in query: DROP DATABASE IF EXISTS test_78gi861n ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:20:10.135929 [ 3769 ] {d080299c-e4f9-4bc0-b619-53ec292b2982} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:10.352663 [ 3715 ] {78c1abad-fe77-44cd-850a-d1802eff3fad} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34638) (comment: 02343_analyzer_lambdas.sql) (in query: DROP DATABASE IF EXISTS test_78gi861n ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:20:10.362940 [ 3715 ] {78c1abad-fe77-44cd-850a-d1802eff3fad} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:11.642124 [ 3723 ] {94adc1b9-3fef-4e8b-806a-5926f6bbfa07} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 128.35 MiB (attempt to allocate chunk of 0 bytes), maximum: 476.84 MiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53458) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x000000001adfe455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfd00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000287c1092 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 @ 0x00000000287d461c 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000002d975255 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x000000002d96f355 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:11.744717 [ 3723 ] {94adc1b9-3fef-4e8b-806a-5926f6bbfa07} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 128.35 MiB (attempt to allocate chunk of 0 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x000000001adfe455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfd00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000287c1092 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 @ 0x00000000287d461c 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000002d975255 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x000000002d96f355 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:12.278047 [ 3769 ] {66675d39-3431-4e25-94f9-656ff4982e0c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=3): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58616) (comment: 00040_aggregating_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW test.basic_00040 ENGINE = AggregatingMergeTree(StartDate, (CounterID, StartDate), 8192) POPULATE AS SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits GROUP BY CounterID, StartDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:12.386931 [ 3769 ] {66675d39-3431-4e25-94f9-656ff4982e0c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=3): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:16.341725 [ 4168 ] {01017e6b-4628-472f-92bc-175cd9c5988f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56048) (comment: 02242_subcolumns_sizes.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:16.369181 [ 4168 ] {01017e6b-4628-472f-92bc-175cd9c5988f} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:18.309969 [ 3769 ] {8b3b2cf9-70b3-4628-be15-c3afe855e083} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=742, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56106) (comment: 00163_column_oriented_formats.sh) (in query: SELECT MobilePhoneModel from 00163_column_oriented), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:18.346844 [ 3769 ] {8b3b2cf9-70b3-4628-be15-c3afe855e083} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=742, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:21.139202 [ 4168 ] {4300e49a-3c56-4563-afea-3ac0f495b996} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56096) (comment: 00620_optimize_on_nonleader_replica_zookeeper.sql) (in query: INSERT INTO rename1 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:20:21.173063 [ 4168 ] {4300e49a-3c56-4563-afea-3ac0f495b996} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:20:21.724366 [ 3908 ] {de20c2b9-84e4-4731-9da2-1bd6e3c0e9f4} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54386) (comment: 00620_optimize_on_nonleader_replica_zookeeper.sql) (in query: DROP DATABASE IF EXISTS test_6rtahzsf ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:20:21.740927 [ 3908 ] {de20c2b9-84e4-4731-9da2-1bd6e3c0e9f4} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:23.937237 [ 2764 ] {28cf9dfd-43c2-4118-b58b-990dc3d41a34} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56076) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:20:24.003147 [ 2764 ] {28cf9dfd-43c2-4118-b58b-990dc3d41a34} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:20:24.507290 [ 2878 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:25.511984 [ 2912 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:25.640906 [ 3769 ] {e9aa3eb9-681f-46f8-a55d-46d8c67c19c6} 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.10521.altinitytest (altinity build)) (from [::1]:56112) (comment: 02125_query_views_log.sql) (in query: select read_rows, read_bytes, written_rows, written_bytes from system.query_log where type = 'QueryFinish' and query_kind = 'Insert' and current_database = currentDatabase() format Vertical;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:20:25.677159 [ 3769 ] {e9aa3eb9-681f-46f8-a55d-46d8c67c19c6} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:20:25.763702 [ 2918 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:26.516816 [ 2947 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:26.767244 [ 2960 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:27.520365 [ 2982 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:27.770104 [ 2990 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:28.208411 [ 4170 ] {427ce9b7-174f-419c-a4ed-bcb3b371122a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=14): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56184) (comment: 01504_compression_multiple_streams.sql) (in query: SELECT * FROM columns_with_multiple_streams ORDER BY field0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027c30b46 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002defb871 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:20:28.279866 [ 4170 ] {427ce9b7-174f-419c-a4ed-bcb3b371122a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=14): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:666: DB::SerializationTuple::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027c30b46 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002defb871 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:20:28.527555 [ 3015 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:28.772587 [ 3026 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:29.531514 [ 3045 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:29.560747 [ 4170 ] {8d020113-5e72-4b81-ba22-2edbc325a08e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57916) (comment: 00045_uniq_upto.sql) (in query: SELECT RegionID, uniqExact(UserID) AS u1, uniqUpTo(10)(UserID) AS u2 FROM test.visits GROUP BY RegionID HAVING u1 <= 11 AND u1 != u2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:29.586746 [ 4170 ] {8d020113-5e72-4b81-ba22-2edbc325a08e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:29.775168 [ 3054 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:29.900491 [ 3723 ] {424d4201-2bef-4e8f-b0d0-f8462aa5b8fc} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 176.65 MiB (attempt to allocate chunk of 8519680 bytes), maximum: 476.84 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53458) (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=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x000000001adfe455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfd00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ad313ff 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000aaaf240 9. ./src/Columns/ColumnString.h:184: DB::(anonymous namespace)::GroupArrayGeneralImpl>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002298f7a8 10. ./build_docker/./src/Columns/ColumnAggregateFunction.cpp:176: DB::ColumnAggregateFunction::convertToValues(COW::mutable_ptr) @ 0x000000002ab192ad 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: DB::finalizeChunk(DB::Chunk&, std::vector> const&) @ 0x000000002db9a02f 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 18. ./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*) @ 0x000000002d37c7d7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:20:30.095555 [ 3723 ] {424d4201-2bef-4e8f-b0d0-f8462aa5b8fc} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 176.65 MiB (attempt to allocate chunk of 8519680 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x000000001adfe455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfd00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 7. ./build_docker/./src/Common/Allocator.cpp:0: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000001ad313ff 8. void DB::PODArrayBase<1ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000aaaf240 9. ./src/Columns/ColumnString.h:184: DB::(anonymous namespace)::GroupArrayGeneralImpl>::insertResultInto(char*, DB::IColumn&, DB::Arena*) const @ 0x000000002298f7a8 10. ./build_docker/./src/Columns/ColumnAggregateFunction.cpp:176: DB::ColumnAggregateFunction::convertToValues(COW::mutable_ptr) @ 0x000000002ab192ad 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:140: DB::finalizeChunk(DB::Chunk&, std::vector> const&) @ 0x000000002db9a02f 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 18. ./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*) @ 0x000000002d37c7d7 19. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:20:30.542841 [ 3074 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:30.777806 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:30.893483 [ 2766 ] {473081fa-6214-44f8-8a40-9b302ae2433c} executeQuery: Code: 57. DB::Exception: Table test_5.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00174_distinct_in_order.sql) (in query: /* ddl_entry=query-0000000004 */ CREATE TABLE test_5.distinct_in_order UUID '6bb0fc74-014a-4143-a841-dfba1718c2c8' (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 786509478, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 251186260, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8386921, merge_max_block_size = 21329, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 31, min_merge_bytes_to_use_direct_io = 1502866572, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 49807, primary_key_compress_block_size = 99961), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868a990 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686673 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027dae9a2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6348b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b185c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:20:31.065050 [ 2766 ] {473081fa-6214-44f8-8a40-9b302ae2433c} executeQuery: Code: 57. DB::Exception: Table test_5.distinct_in_order already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56248) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE distinct_in_order (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 786509478, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 251186260, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 8386921, merge_max_block_size = 21329, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 31, min_merge_bytes_to_use_direct_io = 1502866572, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 49807, primary_key_compress_block_size = 99961), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868a990 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686673 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027dae9a2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6348b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b185c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:20:31.136604 [ 2766 ] {473081fa-6214-44f8-8a40-9b302ae2433c} TCPHandler: Code: 57. DB::Exception: Table test_5.distinct_in_order already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868a990 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686673 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027dae9a2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6348b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b185c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:20:31.545788 [ 3114 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:31.780296 [ 3121 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:32.548363 [ 3144 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:32.782816 [ 3156 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:33.551176 [ 3180 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:33.785611 [ 3190 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:34.214322 [ 2764 ] {97586eb3-cb94-40dc-9ee1-31dbc0c8e23b} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58052) (comment: 03039_dynamic_aggregating_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sum` AggregateFunction(sum, UInt64), `d` Dynamic) ENGINE = AggregatingMergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000000, vertical_merge_algorithm_min_columns_to_activate = 1000000000000, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 513889911, compact_parts_max_bytes_to_buffer = 508344845, compact_parts_max_granules_to_buffer = 215, compact_parts_merge_max_bytes_to_prefetch_part = 18441175, merge_max_block_size = 8128, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 12002, primary_key_compress_block_size = 23822), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:34.246490 [ 2764 ] {97586eb3-cb94-40dc-9ee1-31dbc0c8e23b} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:34.553460 [ 3218 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:34.788530 [ 3223 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:35.557189 [ 3248 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:35.743303 [ 4167 ] {73cdd1db-9005-4587-9a08-f9750ed1f66d} 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.10521.altinitytest (altinity build)) (from [::1]:57996) (comment: 01852_dictionary_found_rate_long.sql) (in query: SELECT * FROM simple_key_flat_dictionary_01862 WHERE id = 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:20:35.764521 [ 4167 ] {73cdd1db-9005-4587-9a08-f9750ed1f66d} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:20:35.791453 [ 3257 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:36.561126 [ 3284 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:36.578853 [ 3282 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:36.796968 [ 3280 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:37.572289 [ 3302 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:37.800090 [ 3308 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:37.919922 [ 2766 ] {d2ed87d7-ab54-4f1a-a21d-dcbef448f2c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47102) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:37.947762 [ 2766 ] {d2ed87d7-ab54-4f1a-a21d-dcbef448f2c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:38.575510 [ 3330 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:38.701188 [ 3715 ] {83fdad37-fdf3-4f86-ba4f-aaafe5631433} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=742, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47148) (comment: 02662_sparse_columns_mutations_4.sql) (in query: INSERT INTO t_sparse_mutations_4 SELECT number, 0 FROM numbers(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d355df7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d1870e3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:20:38.732522 [ 3715 ] {83fdad37-fdf3-4f86-ba4f-aaafe5631433} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=742, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d355df7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d1870e3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:20:38.804574 [ 2822 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:39.041728 [ 3896 ] {5aa90419-9a91-4400-a083-71d1f8d042bf} 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.10521.altinitytest (altinity build)) (from [::1]:47118) (comment: 01640_distributed_async_insert_compression.sql) (in query: SELECT count() FROM local;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:20:39.056171 [ 3896 ] {5aa90419-9a91-4400-a083-71d1f8d042bf} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:20:39.578863 [ 2847 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:39.807966 [ 2838 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:40.582468 [ 2844 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:40.811376 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:41.585860 [ 2896 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:41.815027 [ 2902 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:42.589231 [ 2920 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:42.820203 [ 2927 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:43.221875 [ 3723 ] {8bebd7ec-9c08-4c31-9b6c-e7c87ffd3438} executeQuery: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47252) (comment: 01680_date_time_add_ubsan.sql) (in query: SELECT DISTINCT result FROM (SELECT toStartOfFifteenMinutes(toDateTime(toStartOfFifteenMinutes(toDateTime(1000.0001220703125) + (number * 65536))) + (number * 9223372036854775807)) AS result FROM system.numbers LIMIT 1048576) ORDER BY result DESC NULLS FIRST 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee508f 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee26b6 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000ced17ae 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cece3a7 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000016eae11f 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eac360 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:43.229859 [ 3723 ] {8bebd7ec-9c08-4c31-9b6c-e7c87ffd3438} TCPHandler: Code: 407. DB::Exception: Numeric overflow: while executing 'FUNCTION plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))) :: 3, multiply(__table2.number, 9223372036854775807_UInt64) :: 2) -> plus(toDateTime(toStartOfFifteenMinutes(plus(_CAST(1000_DateTime, 'DateTime'_String), multiply(__table2.number, 65536_UInt32)))), multiply(__table2.number, 9223372036854775807_UInt64)) DateTime : 0'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee508f 5. void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000cee26b6 6. DB::DateTimeAddIntervalImpl::execute(DB::AddSecondsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000ced17ae 7. DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cece3a7 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 13. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000016eae11f 14. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eac360 15. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 20. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 21. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 22. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:20:43.592811 [ 2947 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:43.823377 [ 2951 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:44.598438 [ 2968 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:44.826572 [ 2972 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:45.486240 [ 4170 ] {b508b017-da1f-4cd4-ac71-a002562de511} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47188) (comment: 00053_replicate_segfault.sql) (in query: SELECT count() > 0 FROM (SELECT ParsedParams.Key1 AS p FROM test.visits WHERE arrayAll(y -> arrayExists(x -> y != x, p), p)) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:20:45.494846 [ 4170 ] {b508b017-da1f-4cd4-ac71-a002562de511} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:20:45.601463 [ 2989 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:45.830030 [ 2996 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:46.085326 [ 2766 ] {d26676be-f3ce-4c69-a879-619ace12294f} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51244) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(JSONEachRow, '{"x" : 1, "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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.091867 [ 2766 ] {d26676be-f3ce-4c69-a879-619ace12294f} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.243034 [ 2766 ] {44d1be85-ef77-43ea-9865-86e641129658} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51244) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(JSONEachRow, '{"x" : 1, "y" : 2}\n{"x" : 2, "x" : 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.247731 [ 2766 ] {44d1be85-ef77-43ea-9865-86e641129658} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a JSONEachRow format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "x". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.406414 [ 2766 ] {68acd00e-6649-4e06-bc2d-731d922b3928} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSVWithNames format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51244) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(CSVWithNames, 'a,b,a\n1,2,3');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.415663 [ 2766 ] {68acd00e-6649-4e06-bc2d-731d922b3928} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSVWithNames format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.564365 [ 2766 ] {feb7d034-0470-4d96-8226-a8adb82790a6} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51244) (comment: 02455_duplicate_column_names_in_schema_inference.sql) (in query: desc format(CSV, '1,2,3') settings column_names_for_schema_inference='a, b, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.569101 [ 2766 ] {feb7d034-0470-4d96-8226-a8adb82790a6} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file. Error: Code: 117. DB::Exception: Duplicate column name found while schema inference: "a". (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x00000000180b6b3a 4. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:280: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d37c6 5. ./build_docker/./src/Formats/ReadSchemaUtils.cpp:0: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000002d2d597b 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x000000002603f82b 7. ./contrib/boost/boost/multi_index_container.hpp:640: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000029bf2b4c 8. ./build_docker/./src/Interpreters/InterpreterDescribeQuery.cpp:0: DB::InterpreterDescribeQuery::execute() @ 0x0000000029bf0d43 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:20:46.604831 [ 3011 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:46.832793 [ 3015 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:47.712491 [ 3031 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:47.847355 [ 3035 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:48.681504 [ 2764 ] {af4c7ad5-06ca-41f0-9441-75cfc44eda67} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51332) (comment: 00045_uniq_upto.sql) (in query: SELECT RegionID, uniqExact(UserID) AS u1, uniqUpTo(10)(UserID) AS u2 FROM test.visits GROUP BY RegionID HAVING u1 <= 11 AND u1 != u2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:20:48.708659 [ 2764 ] {af4c7ad5-06ca-41f0-9441-75cfc44eda67} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:20:48.715409 [ 3059 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:48.855430 [ 3061 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:49.718179 [ 3075 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:49.859860 [ 3083 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:50.721831 [ 3100 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:50.862293 [ 3101 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:51.728201 [ 3117 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:51.891717 [ 3122 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:52.413853 [ 4167 ] {7aad97b5-6b1e-4afd-acfb-d472f439a347} executeQuery: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51368) (comment: 00152_insert_different_granularity.sql) (in query: -- We have removed testing of OPTIMIZE because it's too heavy on very slow builds (debug + coverage + thread fuzzer with sleeps) -- OPTIMIZE TABLE fixed_granularity_table FINAL; -- and even after optimize DETACH TABLE fixed_granularity_table;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d62412 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d62a5e 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6b5c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:20:52.436326 [ 4167 ] {7aad97b5-6b1e-4afd-acfb-d472f439a347} TCPHandler: Code: 80. DB::Exception: DETACH TABLE is not allowed for Replicated databases. Use DETACH TABLE PERMANENTLY or SYSTEM RESTART REPLICA or set database_replicated_always_detach_permanently to 1. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:979: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d62412 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d62a5e 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6b5c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:20:52.731143 [ 3143 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:52.898993 [ 3146 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:53.004837 [ 2764 ] {84f6871c-8bff-4574-998b-771e47b130f7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51382) (comment: 02900_date_time_check_overflow.sql) (in query: SELECT toDate(toDateTime64('2299-12-31 23:59:59.999', 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:53.021144 [ 2764 ] {84f6871c-8bff-4574-998b-771e47b130f7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:20:53.735701 [ 3164 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:53.902176 [ 3166 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:54.739039 [ 3183 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:54.905906 [ 3188 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:55.743083 [ 3205 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:55.908519 [ 3207 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:56.529569 [ 3884 ] {76d6969b-ab46-4b73-93d5-3984e6f7aef8} void DB::ParallelParsingInputFormat::onBackgroundException(): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:56.541088 [ 5623 ] {76d6969b-ab46-4b73-93d5-3984e6f7aef8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_1/data.tsv.lz4): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51408) (comment: 02238_lz4_bug.sh) (in query: SELECT count(), max(x) FROM 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:20:56.553799 [ 5623 ] {76d6969b-ab46-4b73-93d5-3984e6f7aef8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (in file/uri /var/lib/clickhouse/user_files/test_1/data.tsv.lz4): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:20:56.806424 [ 3230 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:56.914974 [ 3234 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:57.244249 [ 3906 ] {0fba0865-96ed-43b6-980c-dcb49f5ecbae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40514) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:20:57.286056 [ 3906 ] {0fba0865-96ed-43b6-980c-dcb49f5ecbae} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:20:57.809295 [ 3255 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:57.918422 [ 3257 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:58.169708 [ 3896 ] {cd2fd4d0-5a7f-48c0-a8e7-5c4521faa604} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40588) (comment: 00051_min_max_array.sql) (in query: SELECT CounterID, count(), max(GoalsReached), min(GoalsReached), minIf(GoalsReached, notEmpty(GoalsReached)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:20:58.197432 [ 3896 ] {cd2fd4d0-5a7f-48c0-a8e7-5c4521faa604} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:20:58.812541 [ 3284 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:58.922093 [ 3276 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:59.372740 [ 5617 ] {d2e0d19d-7173-446c-81b3-22086c0fc010} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40594) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000002da15e54 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:445: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000002d9ff7e5 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000002da0006d 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000002da1437c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000278419be 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002dde5a01 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:20:59.394648 [ 5617 ] {d2e0d19d-7173-446c-81b3-22086c0fc010} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000002da15e54 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:445: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000002d9ff7e5 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000002da0006d 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000002da1437c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000278419be 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002dde5a01 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:20:59.816578 [ 3301 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:20:59.925039 [ 3303 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:00.300976 [ 4167 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000026d2f378 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000029648752 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) @ 0x000000002d1ee4e6 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d070e96 7. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:00.366718 [ 4167 ] {} DynamicQueryHandler: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000026d2f378 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000029648752 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) @ 0x000000002d1ee4e6 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d070e96 7. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:00.469202 [ 2766 ] {0d39b198-3f91-4c9d-8fa3-0bd22105b075} executeQuery: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=default&password=wrong. HTTP status code: 403 Forbidden, body: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED) (version 24.8.14.10521.altinitytest (altinity build)) : (in file/uri http://127.0.0.1:8123/?query=select+1&user=default&password=wrong): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40568) (comment: 02725_url_support_virtual_column.sql) (in query: select _path, _file, s from url('http://127.0.0.1:8123/?query=select+1&user=default&password=wrong', LineAsString, 's String');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3befac 4. ./src/Common/Exception.h:43: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3bf2f4 5. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000001b3becf1 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001b536613 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001b536b39 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001b537d39 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001b53d4d8 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b5325f1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001b53a4a3 12. DB::ReadBuffer::next() @ 0x000000000b52aaeb 13. ./src/IO/ReadBuffer.h:0: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d649fa8 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 16. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 22. ./build_docker/./src/Storages/StorageURL.cpp:426: DB::StorageURLSource::generate() @ 0x000000002bd8087d 23. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:21:00.489319 [ 2766 ] {0d39b198-3f91-4c9d-8fa3-0bd22105b075} TCPHandler: Code: 86. DB::Exception: Received error from remote server http://127.0.0.1:8123/?query=select+1&user=default&password=wrong. HTTP status code: 403 Forbidden, body: Code: 516. DB::Exception: default: Authentication failed: password is incorrect, or there is no user with such name. If you have installed ClickHouse and forgot password you can reset it in the configuration file. The password for default user is typically located at /etc/clickhouse-server/users.d/default-password.xml and deleting this file will reset the password. See also /etc/clickhouse-server/users.xml on the server where ClickHouse is installed. . (AUTHENTICATION_FAILED) (version 24.8.14.10521.altinitytest (altinity build)) : (in file/uri http://127.0.0.1:8123/?query=select+1&user=default&password=wrong): While executing LineAsStringRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3befac 4. ./src/Common/Exception.h:43: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3bf2f4 5. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000001b3becf1 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001b536613 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001b536b39 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001b537d39 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001b53d4d8 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b5325f1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001b53a4a3 12. DB::ReadBuffer::next() @ 0x000000000b52aaeb 13. ./src/IO/ReadBuffer.h:0: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d649fa8 14. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 15. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 16. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 21. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 22. ./build_docker/./src/Storages/StorageURL.cpp:426: DB::StorageURLSource::generate() @ 0x000000002bd8087d 23. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:21:00.819962 [ 3321 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:00.928703 [ 3323 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:01.435128 [ 5618 ] {10d05bf2-75bf-4e55-a6c7-ae4dc32c5b94} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40628) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:21:01.450200 [ 5618 ] {10d05bf2-75bf-4e55-a6c7-ae4dc32c5b94} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:21:01.766436 [ 2831 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:01.825904 [ 2840 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:01.933365 [ 2835 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:02.829440 [ 2863 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:02.841304 [ 5626 ] {9c075d13-68aa-41ae-92e3-85e7092d2b9e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=728). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40670) (comment: 02960_partition_by_udf.sql) (in query: SELECT count() FROM hit;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:02.858193 [ 5626 ] {9c075d13-68aa-41ae-92e3-85e7092d2b9e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=728). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:02.938735 [ 2864 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:03.270001 [ 5621 ] {21f146a4-8553-48c5-8603-7e70a059b659} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58322) (comment: 02960_partition_by_udf.sql) (in query: DROP DATABASE IF EXISTS test_hbj10t47 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:03.284381 [ 5629 ] {5a7ec4b9-4477-416e-b208-a881434f1d14} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40726) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, 'a Tuple(b UInt32)', '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:03.290628 [ 5621 ] {21f146a4-8553-48c5-8603-7e70a059b659} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:03.293655 [ 5629 ] {5a7ec4b9-4477-416e-b208-a881434f1d14} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:03.495128 [ 5629 ] {6e99d026-ef6f-47c3-af3b-649b90d21e87} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40726) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:03.508467 [ 5629 ] {6e99d026-ef6f-47c3-af3b-649b90d21e87} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:03.605929 [ 5629 ] {99d38a3d-78bc-4996-abc7-4225362480d0} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40726) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : 2, "b" : 3}, "c" : 42}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:03.611542 [ 5629 ] {99d38a3d-78bc-4996-abc7-4225362480d0} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:03.834514 [ 2878 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:03.947883 [ 2880 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:04.033638 [ 5629 ] {ea02980e-06b8-4521-80aa-f4fa78b43f36} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40726) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : "Hello"}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:04.043302 [ 5629 ] {ea02980e-06b8-4521-80aa-f4fa78b43f36} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:04.475003 [ 5629 ] {01cf1bbf-0cca-4e2a-89b5-da21ef17e4d7} executeQuery: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40726) (comment: 03284_json_object_as_tuple_duplicate_keys.sql) (in query: select * from format(JSONEachRow, '{"a" : {"b" : 1, "b" : {"c" : "Hello"}}}');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:04.479818 [ 5629 ] {01cf1bbf-0cca-4e2a-89b5-da21ef17e4d7} TCPHandler: Code: 117. DB::Exception: JSON object contains duplicate key 'b': (while reading the value of key a): (at row 1) : While executing JSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:407: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const::'lambda'()::operator()() const @ 0x0000000027c3e802 5. ./build_docker/./src/DataTypes/Serializations/SerializationTuple.cpp:89: void DB::SerializationTuple::deserializeTextJSONImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027c379d6 6. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:880: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b82622 7. ./build_docker/./src/Formats/JSONUtils.cpp:0: DB::JSONUtils::readField(DB::ReadBuffer&, DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, String const&, DB::FormatSettings const&, bool) @ 0x000000002d602a96 8. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:139: DB::JSONEachRowRowInputFormat::readField(unsigned long, std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d631148 9. ./build_docker/./src/Processors/Formats/Impl/JSONEachRowRowInputFormat.cpp:0: DB::JSONEachRowRowInputFormat::readJSONObject(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&) @ 0x000000002d6316da 10. ./src/Processors/ISource.h:41: DB::JSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d632187 11. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 12. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 18. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 19. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 20. ./build_docker/./src/TableFunctions/TableFunctionFormat.cpp:0: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000260416de 21. ./build_docker/./src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000265c521e 22. ./build_docker/./src/Interpreters/Context.cpp:2234: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000028539c72 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4838: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028373cce 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 2025.10.15 20:21:04.838152 [ 2904 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:04.954911 [ 2897 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:05.845279 [ 2915 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:05.960912 [ 2919 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:06.235855 [ 5619 ] {917bdce6-8c3f-498f-b12a-b22e40626899} executeQuery: Code: 8. DB::Exception: Cannot find column `toString(if(in(__table1.TraficSourceID, __set_Int8_3466105182647075530_15547238582023135103), _CAST('type_in'_String, 'Enum8(\'other\' = 1, \'type_in\' = 2)'_String), _CAST('other'_String, 'Enum8(\'other\' = 1, \'type_in\' = 2)'_String)))` in source stream, there are only columns: [__table1.StartDate, toString(if(in(__table1.TraficSourceID, __set_Int8_3466105182647075530_15547238582023135103), _CAST(2_Enum8('other' = 1, 'type_in' = 2), 'Enum8('other' = 1, 'type_in' = 2)'_String), _CAST(1_Enum8('other' = 1, 'type_in' = 2), 'Enum8('other' = 1, 'type_in' = 2)'_String))), sum(__table1.Sign)]. (THERE_IS_NO_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47278) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1505: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002826f0f7 5. ./build_docker/./src/Processors/QueryPlan/ConvertingActions.cpp:20: DB::addConvertingActions(DB::QueryPlan&, DB::Block const&, bool) @ 0x000000002dd9d9ed 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000002de0923a 7. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:593: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aab1853 8. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:683: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aab4b28 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:972: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029473286 10. ./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&) @ 0x000000002946217d 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:21:06.253513 [ 5619 ] {917bdce6-8c3f-498f-b12a-b22e40626899} TCPHandler: Code: 8. DB::Exception: Cannot find column `toString(if(in(__table1.TraficSourceID, __set_Int8_3466105182647075530_15547238582023135103), _CAST('type_in'_String, 'Enum8(\'other\' = 1, \'type_in\' = 2)'_String), _CAST('other'_String, 'Enum8(\'other\' = 1, \'type_in\' = 2)'_String)))` in source stream, there are only columns: [__table1.StartDate, toString(if(in(__table1.TraficSourceID, __set_Int8_3466105182647075530_15547238582023135103), _CAST(2_Enum8('other' = 1, 'type_in' = 2), 'Enum8('other' = 1, 'type_in' = 2)'_String), _CAST(1_Enum8('other' = 1, 'type_in' = 2), 'Enum8('other' = 1, 'type_in' = 2)'_String))), sum(__table1.Sign)]. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1505: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x000000002826f0f7 5. ./build_docker/./src/Processors/QueryPlan/ConvertingActions.cpp:20: DB::addConvertingActions(DB::QueryPlan&, DB::Block const&, bool) @ 0x000000002dd9d9ed 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::createLocalPlanForParallelReplicas(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr, std::unique_ptr>, unsigned long) @ 0x000000002de0923a 7. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:593: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::Block const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aab1853 8. ./build_docker/./src/Interpreters/ClusterProxy/executeQuery.cpp:683: DB::ClusterProxy::executeQueryWithParallelReplicas(DB::QueryPlan&, DB::StorageID const&, DB::QueryProcessingStage::Enum, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr> const>, std::unique_ptr>) @ 0x000000002aab4b28 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:972: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000029473286 10. ./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&) @ 0x000000002946217d 11. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 12. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 13. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:21:06.610612 [ 3769 ] {75c04073-13c2-44e1-8f05-df3a9f7a6883} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51322) (comment: 00172_hits_joins.gen.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY LEFT JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC LIMIT 20 SETTINGS any_join_distinct_right_table_keys = 1, joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:06.651140 [ 3769 ] {75c04073-13c2-44e1-8f05-df3a9f7a6883} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:06.850827 [ 2939 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:06.964136 [ 2938 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:07.853824 [ 2953 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:07.968914 [ 2957 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:08.941401 [ 2970 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:08.971979 [ 2973 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:09.944955 [ 2985 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:09.976167 [ 2988 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:10.948675 [ 3001 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:10.979615 [ 3003 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:11.311741 [ 5621 ] {test_1_20953} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BAD'): BAD SQL. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, ALTER query, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58206) (comment: 02564_query_id_header.sh) (in query: BAD SQL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:21:11.320578 [ 5621 ] {test_1_20953} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BAD'): BAD SQL. Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, ALTER query, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:11.952094 [ 3025 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:11.986459 [ 3026 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:12.184758 [ 4171 ] {904451c6-7492-404e-95bd-fb5d2c75ec39} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47392) (comment: 00063_loyalty_joins.sql) (in query: SELECT loyalty, count() FROM test.hits ANY LEFT JOIN ( SELECT UserID, sum(SearchEngineID = 2) AS yandex, sum(SearchEngineID = 3) AS google, toInt8(if(yandex > google, yandex / (yandex + google), -google / (yandex + google)) * 10) AS loyalty FROM test.hits WHERE (SearchEngineID = 2) OR (SearchEngineID = 3) GROUP BY UserID HAVING (yandex + google) > 10 ) USING UserID GROUP BY loyalty ORDER BY loyalty ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:917: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294ab6bf 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:12.190083 [ 4171 ] {904451c6-7492-404e-95bd-fb5d2c75ec39} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:917: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294ab6bf 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:12.961711 [ 3043 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:12.994066 [ 3045 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:13.024097 [ 4171 ] {a0a950e1-acc4-4b3f-b649-7de94995d178} executeQuery: Code: 57. DB::Exception: Table test_ff2ruesz.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47414) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:13.035608 [ 4171 ] {a0a950e1-acc4-4b3f-b649-7de94995d178} TCPHandler: Code: 57. DB::Exception: Table test_ff2ruesz.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:13.214741 [ 5621 ] {6e336ae1-f788-4471-be15-7928a9f6573f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47966) (comment: 00702_join_with_using_dups.sql) (in query: DROP DATABASE IF EXISTS test_6wu2vb6f ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:13.237958 [ 5621 ] {6e336ae1-f788-4471-be15-7928a9f6573f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:13.566898 [ 5629 ] {62ee8de4-ce58-4a02-8f85-2aeb4f3e592e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47974) (comment: 00702_join_with_using_dups.sql) (in query: DROP DATABASE IF EXISTS test_6wu2vb6f ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:13.577201 [ 5629 ] {62ee8de4-ce58-4a02-8f85-2aeb4f3e592e} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:13.967455 [ 3069 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:13.997845 [ 3071 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:14.274499 [ 3908 ] {bcbfc5b2-1998-44d3-991b-1970c292563b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47424) (comment: 00080_array_join_and_union.sql) (in query: SELECT count() FROM (SELECT Goals.ID FROM test.visits ARRAY JOIN Goals WHERE CounterID = 842440 LIMIT 10 UNION ALL SELECT Goals.ID FROM test.visits ARRAY JOIN Goals WHERE CounterID = 842440 LIMIT 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9b35 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:21:14.358928 [ 3908 ] {bcbfc5b2-1998-44d3-991b-1970c292563b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9b35 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:21:14.971064 [ 3088 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:15.001355 [ 3087 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:16.006010 [ 3102 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:16.042410 [ 3097 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:17.009454 [ 3122 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:17.092109 [ 3121 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:18.012783 [ 3148 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:18.096180 [ 3149 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:19.018341 [ 3163 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:19.102182 [ 3165 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:20.022756 [ 3192 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:20.109895 [ 3194 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:21.025403 [ 3214 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:21.114528 [ 3217 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:22.028246 [ 3240 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:22.117441 [ 3242 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:22.392242 [ 2766 ] {ed6f7ec7-a056-40d8-9910-ac2476dbc917} executeQuery: Code: 57. DB::Exception: Table test_ff2ruesz.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49136) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:22.406622 [ 2766 ] {ed6f7ec7-a056-40d8-9910-ac2476dbc917} TCPHandler: Code: 57. DB::Exception: Table test_ff2ruesz.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:23.030654 [ 3260 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:23.120374 [ 3261 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:24.037796 [ 3284 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:24.135900 [ 3285 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:25.044354 [ 3293 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:25.138999 [ 3303 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:26.049125 [ 3322 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:26.142111 [ 3325 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:26.527197 [ 3906 ] {2ad7dc6b-517b-4322-8bc6-6cc51867f44b} executeQuery: Code: 57. DB::Exception: Table test_ff2ruesz.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58606) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:26.558681 [ 3906 ] {2ad7dc6b-517b-4322-8bc6-6cc51867f44b} TCPHandler: Code: 57. DB::Exception: Table test_ff2ruesz.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:27.053632 [ 2837 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:27.145351 [ 2848 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:27.588935 [ 5617 ] {47b82f2c-4b4b-45a9-9321-721bca003fa4} executeQuery: Code: 471. DB::Exception: Sanity check: 'poll_max_batch_size' value is too high (18446744073709). (INVALID_SETTING_VALUE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58616) (comment: 03010_file_log_large_poll_batch_size.sql) (in query: create table test (number UInt64) engine=FileLog('./user_files/data.jsonl', 'JSONEachRow') settings poll_max_batch_size=18446744073709;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x0000000028596bf4 4. ./build_docker/./src/Storages/FileLog/FileLogSettings.cpp:45: DB::FileLogSettings::loadFromQuery(DB::ASTStorage&) @ 0x000000002bedbf4a 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:815: 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&) @ 0x000000002be905d7 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b782bf3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:27.595968 [ 5617 ] {47b82f2c-4b4b-45a9-9321-721bca003fa4} TCPHandler: Code: 471. DB::Exception: Sanity check: 'poll_max_batch_size' value is too high (18446744073709). (INVALID_SETTING_VALUE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception&>(int, FormatStringHelperImpl&>::type>, DB::SettingFieldNumber&) @ 0x0000000028596bf4 4. ./build_docker/./src/Storages/FileLog/FileLogSettings.cpp:45: DB::FileLogSettings::loadFromQuery(DB::ASTStorage&) @ 0x000000002bedbf4a 5. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:815: 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&) @ 0x000000002be905d7 6. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b782bf3 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:28.056877 [ 2860 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:28.176995 [ 3906 ] {0833be84-848e-4ed4-a475-b7ae87904c3b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1): (while reading column RegionID): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_4_4_0/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 50818): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57346) (comment: 00046_uniq_upto_distributed.sql) (in query: SELECT `__table1`.`RegionID` AS `RegionID`, uniqExact(`__table1`.`UserID`) AS `u1`, uniqUpTo(10)(`__table1`.`UserID`) AS `u2` FROM `test`.`visits` AS `__table1` GROUP BY `__table1`.`RegionID` HAVING (uniqExact(`__table1`.`UserID`) <= 11) AND (uniqExact(`__table1`.`UserID`) != uniqUpTo(10)(`__table1`.`UserID`))), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ea3a9 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&) @ 0x000000002c80f3d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c80a315 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c80994b 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>>&) @ 0x000000002c80aafa 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002deb5454 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:28.178338 [ 2864 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:28.207958 [ 3906 ] {0833be84-848e-4ed4-a475-b7ae87904c3b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1): (while reading column RegionID): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_4_4_0/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 50818): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ea3a9 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&) @ 0x000000002c80f3d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c80a315 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c80994b 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>>&) @ 0x000000002c80aafa 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002deb5454 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:28.368678 [ 2766 ] {5b4eaa8f-8b00-4d20-84f6-be6e1d83c1b6} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1): (while reading column RegionID): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_4_4_0/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 50818): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ea3a9 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&) @ 0x000000002c80f3d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c80a315 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c80994b 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>>&) @ 0x000000002c80aafa 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002deb5454 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58596) (comment: 00046_uniq_upto_distributed.sql) (in query: SELECT RegionID, uniqExact(UserID) AS u1, uniqUpTo(10)(UserID) AS u2 FROM remote('127.0.0.{1,2}', test, visits) GROUP BY RegionID HAVING u1 <= 11 AND u1 != u2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfa817e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:21:28.394843 [ 2766 ] {5b4eaa8f-8b00-4d20-84f6-be6e1d83c1b6} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=1): (while reading column RegionID): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_4_4_0/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 50818): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ea3a9 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&) @ 0x000000002c80f3d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c80a315 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c80994b 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>>&) @ 0x000000002c80aafa 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002deb5454 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 : 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfa817e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:21:29.060758 [ 2879 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:29.182010 [ 2878 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:29.286336 [ 3896 ] {6ebcd072-4d93-435d-bf65-39b35083ce1d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58682) (comment: 01825_type_json_field.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:21:29.292442 [ 3896 ] {6ebcd072-4d93-435d-bf65-39b35083ce1d} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:21:29.757202 [ 2766 ] {ce303671-6f10-457b-b5f7-ce025e3f8422} executeQuery: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT round(toDecimal32(1, 0), -9223372036854775806). (ARGUMENT_OUT_OF_BOUND) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58676) (comment: 01535_decimal_round_scale_overflow_check.sql) (in query: SELECT round(toDecimal32(1, 0), -9223372036854775806);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr DB::Dispatcher, (DB::RoundingMode)8, (DB::TieBreakingMode)0>::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000c581705 5. bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000c4601e9 6. DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c44bfd2 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:21:29.763323 [ 2766 ] {ce303671-6f10-457b-b5f7-ce025e3f8422} TCPHandler: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT round(toDecimal32(1, 0), -9223372036854775806). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr DB::Dispatcher, (DB::RoundingMode)8, (DB::TieBreakingMode)0>::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000c581705 5. bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000c4601e9 6. DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c44bfd2 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:21:29.838896 [ 5618 ] {48c4e0d6-74c7-4857-a043-33b7595b3d5f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40704) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:29.845918 [ 5618 ] {48c4e0d6-74c7-4857-a043-33b7595b3d5f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:30.064091 [ 2899 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:30.185797 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:31.067328 [ 2915 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:31.188816 [ 2920 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:31.363427 [ 3723 ] {a7d9a1b2-a23f-451a-90fe-2b633cfc39f6} executeQuery: Code: 57. DB::Exception: Table test_ff2ruesz.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58744) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:31.387054 [ 3723 ] {a7d9a1b2-a23f-451a-90fe-2b633cfc39f6} TCPHandler: Code: 57. DB::Exception: Table test_ff2ruesz.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:32.075392 [ 2934 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:32.192300 [ 2940 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:33.082567 [ 2954 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:33.195922 [ 2958 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:33.553790 [ 2766 ] {06cc3ef1-85b5-4ec2-95a8-3f3a71580292} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45164) (comment: 01710_projection_with_column_transformers.sql) (in query: DROP DATABASE IF EXISTS test_el10hgzw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:33.567377 [ 2766 ] {06cc3ef1-85b5-4ec2-95a8-3f3a71580292} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:33.764488 [ 3723 ] {26cb164e-f32d-4eec-b592-9b77ace1bcfc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45178) (comment: 01710_projection_with_column_transformers.sql) (in query: DROP DATABASE IF EXISTS test_el10hgzw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:33.768628 [ 3723 ] {26cb164e-f32d-4eec-b592-9b77ace1bcfc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:34.058466 [ 3906 ] {169cc0fe-9ed1-4ec9-96cc-72aad438ac5a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45188) (comment: 01710_projection_with_column_transformers.sql) (in query: DROP DATABASE IF EXISTS test_el10hgzw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:34.066692 [ 3906 ] {169cc0fe-9ed1-4ec9-96cc-72aad438ac5a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:34.087599 [ 2974 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:34.131704 [ 4167 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:32808, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aea84aa 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aef85d2 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1974cb 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d184d40 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:34.199262 [ 2976 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:34.348938 [ 5617 ] {4c8104ec-b3fd-4f50-9ed4-3d9f3cadc230} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45194) (comment: 01710_projection_with_column_transformers.sql) (in query: DROP DATABASE IF EXISTS test_el10hgzw ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:21:34.359588 [ 5617 ] {4c8104ec-b3fd-4f50-9ed4-3d9f3cadc230} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:34.361860 [ 3896 ] {fa93434b-6905-4d49-93bb-8c7ee9937c3d} 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.10521.altinitytest (altinity build)) (from [::1]:58796) (comment: 00183_skip_unavailable_shards.sql) (in query: SELECT count() FROM remote('{127,1}.0.0.{2,3}', system.one) SETTINGS skip_unavailable_shards = 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:34.366969 [ 3896 ] {fa93434b-6905-4d49-93bb-8c7ee9937c3d} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:34.677209 [ 2766 ] {0926ac6f-4708-4d76-9f85-8b7cfc8e07c7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57364). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57364) (comment: 00183_skip_unavailable_shards.sql) (in query: SELECT count() AS `count()` FROM `system`.`one` 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1a1a4b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19bd1e 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:21:34.680642 [ 2766 ] {0926ac6f-4708-4d76-9f85-8b7cfc8e07c7} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:57364). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1a1a4b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19bd1e 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:21:34.683892 [ 2766 ] {0926ac6f-4708-4d76-9f85-8b7cfc8e07c7} TCPHandler: Client has gone away. 2025.10.15 20:21:35.090549 [ 2994 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:35.204165 [ 3001 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:35.213311 [ 2995 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:36.093635 [ 3021 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:36.278141 [ 3026 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:36.462821 [ 3449 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {24310d89-f4f4-4694-b8de-dac7140488d3::202510_1_39_12}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:36.766541 [ 4167 ] {d82a8554-9d55-443a-8b84-1eb10ac16fab} 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.10521.altinitytest (altinity build)) (from [::1]:58020) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:36.793634 [ 4167 ] {d82a8554-9d55-443a-8b84-1eb10ac16fab} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:37.097111 [ 3049 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:37.183031 [ 3715 ] {5fdf75aa-f468-446b-b21e-fcd68586c9a3} 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.10521.altinitytest (altinity build)) (from [::1]:58852) (comment: 00177_memory_bound_merging.sh) (in query: SELECT COUNT() > 0 FROM system.text_log WHERE query_id IN (SELECT query_id FROM system.query_log WHERE query_id != 'query_id_memory_bound_merging_13547139' AND initial_query_id = 'query_id_memory_bound_merging_13547139' AND event_date >= yesterday()) AND event_date >= yesterday() AND message ILIKE '%Reading%ranges in order%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:21:37.190870 [ 3715 ] {5fdf75aa-f468-446b-b21e-fcd68586c9a3} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:21:37.282259 [ 3057 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:38.100595 [ 3079 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:38.285226 [ 3083 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:38.584876 [ 4171 ] {query_id_memory_bound_merging_2054123411} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58058) (comment: 00177_memory_bound_merging.sh) (in query: SELECT URL, EventDate, max(URL) FROM remote(test_cluster_one_shard_two_replicas, test.hits) WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY URL, EventDate ORDER BY URL, EventDate LIMIT 5 OFFSET 10 SETTINGS optimize_aggregation_in_order = 1, enable_memory_bound_merging_of_aggregation_results = 1, enable_parallel_replicas = 1, parallel_replicas_for_non_replicated_merge_tree = 1, max_parallel_replicas = 3, query_plan_aggregation_in_order = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:38.595910 [ 4171 ] {query_id_memory_bound_merging_2054123411} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:39.104038 [ 3102 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:39.288348 [ 3105 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:40.028003 [ 3447 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ff640274-a70d-474b-b6eb-15ad6e6c74ba::202510_1_15_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:40.107885 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:40.291625 [ 3139 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:41.110463 [ 3160 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:41.294687 [ 3169 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:41.664151 [ 5629 ] {213140e5-927b-4a3b-be1d-2147ec359941} 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.10521.altinitytest (altinity build)) (from [::1]:58088) (comment: 00177_memory_bound_merging.sh) (in query: SELECT COUNT() > 0 FROM system.text_log WHERE query_id IN (SELECT query_id FROM system.query_log WHERE query_id != 'query_id_memory_bound_merging_2054123411' AND initial_query_id = 'query_id_memory_bound_merging_2054123411' AND event_date >= yesterday()) AND event_date >= yesterday() AND message ILIKE '%Reading%ranges in order%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000002de45c5e 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000002dfb7bff 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df73256 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de10e8a 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0f90b 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:21:41.706029 [ 5629 ] {213140e5-927b-4a3b-be1d-2147ec359941} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000002de45c5e 10. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeUseAggregateProjection.cpp:604: DB::QueryPlanOptimizations::optimizeUseAggregateProjections(DB::QueryPlan::Node&, std::list>&, bool) @ 0x000000002dfb7bff 11. ./contrib/llvm-project/libcxx/include/optional:344: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df73256 12. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de10e8a 13. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0f90b 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:21:42.113661 [ 3188 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:42.306261 [ 3189 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:42.794622 [ 3908 ] {336b14e8-9486-40fc-b017-1f20b33eb840} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58102) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 25152951;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:42.810616 [ 3908 ] {336b14e8-9486-40fc-b017-1f20b33eb840} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:43.117187 [ 3214 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:43.309200 [ 3219 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:44.120073 [ 3241 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:44.312600 [ 3250 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:44.825530 [ 5629 ] {d3c6732d-5900-4b52-b4df-68668fd0fd7d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=7): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58130) (comment: 00046_uniq_upto_distributed.sql) (in query: SELECT RegionID, uniqExact(UserID) AS u1, uniqUpTo(10)(UserID) AS u2 FROM remote('127.0.0.{1,2}', test, visits) GROUP BY RegionID HAVING u1 <= 11 AND u1 != u2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:44.860782 [ 5629 ] {d3c6732d-5900-4b52-b4df-68668fd0fd7d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=7): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:21:45.122948 [ 3258 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:45.316428 [ 3262 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:45.530250 [ 5617 ] {f56bc138-35bd-47d7-a0a5-cf4c097007b2} executeQuery: Code: 432. DB::Exception: Unknown codec family: gbdgkjsdh. (UNKNOWN_CODEC) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57994) (comment: 00804_test_alter_compression_codecs.sql) (in query: ALTER TABLE alter_bad_codec ADD COLUMN alter_column DateTime DEFAULT '2019-01-01 00:00:00' CODEC(gbdgkjsdh);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Compression/CompressionFactory.cpp:0: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x000000002777b065 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291efecb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291ed75d 9. ./build_docker/./src/Storages/AlterCommands.cpp:1349: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60a5a5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:21:45.537836 [ 5617 ] {f56bc138-35bd-47d7-a0a5-cf4c097007b2} TCPHandler: Code: 432. DB::Exception: Unknown codec family: gbdgkjsdh. (UNKNOWN_CODEC), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Compression/CompressionFactory.cpp:0: DB::CompressionCodecFactory::getImpl(String const&, std::shared_ptr const&, DB::IDataType const*) const @ 0x000000002777b065 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291efecb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291ed75d 9. ./build_docker/./src/Storages/AlterCommands.cpp:1349: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60a5a5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:21:45.819185 [ 5617 ] {e3dade78-64a5-41c2-bc7e-99a63d1eaaa8} executeQuery: Code: 433. DB::Exception: ZSTD codec can't have level more than 22, given 100. (ILLEGAL_CODEC_PARAMETER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57994) (comment: 00804_test_alter_compression_codecs.sql) (in query: ALTER TABLE alter_bad_codec ADD COLUMN alter_column DateTime DEFAULT '2019-01-01 00:00:00' CODEC(ZSTD(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&&, int&) @ 0x000000002778aada 4. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:104: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002778a237 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291efecb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291ed75d 9. ./build_docker/./src/Storages/AlterCommands.cpp:1349: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60a5a5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:21:45.838529 [ 5617 ] {e3dade78-64a5-41c2-bc7e-99a63d1eaaa8} TCPHandler: Code: 433. DB::Exception: ZSTD codec can't have level more than 22, given 100. (ILLEGAL_CODEC_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, int&&, int&) @ 0x000000002778aada 4. ./build_docker/./src/Compression/CompressionCodecZSTD.cpp:104: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x000000002778a237 5. ./build_docker/./src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000291efecb 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 7. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 8. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000291ed75d 9. ./build_docker/./src/Storages/AlterCommands.cpp:1349: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60a5a5 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:21:46.126476 [ 3276 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:46.320696 [ 3280 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:47.130274 [ 3298 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:47.173776 [ 5623 ] {765b0412-7ac2-43cc-ae8b-88f88da13bcd} executeQuery: Code: 43. DB::Exception: Second argument for function addSeconds must be a number. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52696) (comment: 02470_suspicious_low_cardinality_msan.sql) (in query: SELECT colAlias0, colAlias2, colAlias3 FROM alias_2__fuzz_25;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cecf082 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000016eae0d0 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eac360 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 13. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccf6ee 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec64 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 17. ./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) @ 0x000000002825cda8 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002825a797 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9d2e77 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd9df39 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::createComputeAliasColumnsStep(std::unordered_map, std::equal_to, std::allocator>>&, DB::DataStream const&) @ 0x000000002948096a 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002947345b 23. ./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&) @ 0x000000002946217d 24. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 25. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 26. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:21:47.195030 [ 5623 ] {765b0412-7ac2-43cc-ae8b-88f88da13bcd} TCPHandler: Code: 43. DB::Exception: Second argument for function addSeconds must be a number. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::FunctionDateOrDateTimeAddInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cecf082 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. DB::FunctionBinaryArithmetic::executeDateTimeIntervalPlusMinus(std::vector> const&, std::shared_ptr const&, unsigned long, std::shared_ptr const&) const @ 0x0000000016eae0d0 9. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000016eac360 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 13. DB::IExecutableFunction::defaultImplementationForNulls(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccf6ee 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec64 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 17. ./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) @ 0x000000002825cda8 18. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002825a797 19. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9d2e77 20. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd9df39 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::createComputeAliasColumnsStep(std::unordered_map, std::equal_to, std::allocator>>&, DB::DataStream const&) @ 0x000000002948096a 22. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002947345b 23. ./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&) @ 0x000000002946217d 24. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 25. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 26. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:21:47.329153 [ 3304 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:48.135337 [ 3324 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:48.176861 [ 5623 ] {de6b5284-8b13-45a5-bb23-7aef31688f73} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52718) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:48.180203 [ 5623 ] {de6b5284-8b13-45a5-bb23-7aef31688f73} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:21:48.332063 [ 3328 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:49.175068 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:49.339186 [ 2851 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:50.179702 [ 2866 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:50.345118 [ 2865 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:51.184345 [ 2888 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:51.348257 [ 2892 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:51.450991 [ 5618 ] {d1bb085f-d78f-4101-8c1a-d945049cffbd} executeQuery: Code: 57. DB::Exception: Table test.basic_00040 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52776) (comment: 00040_aggregating_materialized_view.sql) (in query: CREATE MATERIALIZED VIEW test.basic_00040 ENGINE = AggregatingMergeTree(StartDate, (CounterID, StartDate), 8192) POPULATE AS SELECT CounterID, StartDate, sumState(Sign) AS Visits, uniqState(UserID) AS Users FROM test.visits GROUP BY CounterID, StartDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:51.458737 [ 5618 ] {d1bb085f-d78f-4101-8c1a-d945049cffbd} TCPHandler: Code: 57. DB::Exception: Table test.basic_00040 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:21:52.189403 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:52.352092 [ 2912 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:53.192821 [ 2929 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:53.355310 [ 2928 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:54.196104 [ 2949 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:54.360301 [ 2955 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:55.199995 [ 2968 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:55.363325 [ 2970 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:56.202981 [ 2990 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:56.366615 [ 2998 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:57.209039 [ 3006 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:57.370345 [ 3013 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:58.212508 [ 3033 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:58.374343 [ 3036 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:59.216818 [ 3049 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:21:59.382666 [ 3052 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:00.220217 [ 3073 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:00.386325 [ 3074 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:01.223787 [ 3085 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:01.391859 [ 3087 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:02.259453 [ 3102 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:02.395271 [ 3097 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:02.943059 [ 4168 ] {0273238a-0027-4928-a4f8-61001be06faa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=735). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52490) (comment: 00623_in_partition_key.sql) (in query: SELECT 323 AS `323` FROM `test_pz3he7z8`.`test54378` AS `__table1` WHERE `__table1`.`pk_date` IN (17640)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:02.952718 [ 4168 ] {0273238a-0027-4928-a4f8-61001be06faa} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=735). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:03.116916 [ 3723 ] {1ad97ebf-2e56-4d6b-bbd2-d69a2472137e} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=735). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58008) (comment: 00623_in_partition_key.sql) (in query: select 323 from test54378 where pk_date in (toDate('2018-04-19'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf9eb9e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b0f96 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:22:03.159946 [ 3723 ] {1ad97ebf-2e56-4d6b-bbd2-d69a2472137e} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=735). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 : 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf9eb9e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b0f96 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:22:03.262417 [ 3123 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:03.398373 [ 3128 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:04.268108 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:04.402405 [ 3149 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:04.923585 [ 3896 ] {5e14b24a-2d95-4c98-a860-f589261a6c53} 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.10521.altinitytest (altinity build)) (from [::1]:46364) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:22:04.954102 [ 3896 ] {5e14b24a-2d95-4c98-a860-f589261a6c53} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:22:05.271920 [ 3162 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:05.408896 [ 3167 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:06.274959 [ 3181 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:06.413522 [ 3184 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:07.278379 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:07.416141 [ 3208 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:08.220109 [ 2766 ] {70eef36b-91d8-4605-aa91-b9f408beeb27} executeQuery: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58704) (comment: 03039_dynamic_aggregating_merge_tree.sh) (in query: CREATE TABLE test (`id` UInt64, `sum` AggregateFunction(sum, UInt64), `d` Dynamic) ENGINE = AggregatingMergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1, min_bytes_for_wide_part = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, index_granularity = 8128, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 513889911, compact_parts_max_bytes_to_buffer = 508344845, compact_parts_max_granules_to_buffer = 215, compact_parts_merge_max_bytes_to_prefetch_part = 18441175, merge_max_block_size = 8128, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 10485760, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 12002, primary_key_compress_block_size = 23822), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:08.234377 [ 2766 ] {70eef36b-91d8-4605-aa91-b9f408beeb27} TCPHandler: Code: 57. DB::Exception: Table test_3.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:08.281813 [ 3219 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:08.467610 [ 3224 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:08.740465 [ 5620 ] {002cb3e0-1d8b-4cfd-ba02-9db04e354f31} executeQuery: Code: 57. DB::Exception: Table test_13.ordinary_distinct already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58680) (comment: 00174_distinct_in_order.sql) (in query: CREATE TABLE ordinary_distinct (`CounterID` UInt32, `EventDate` Date) ENGINE = MergeTree ORDER BY (CounterID, EventDate) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 731301428, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 163298642, compact_parts_max_granules_to_buffer = 108, compact_parts_merge_max_bytes_to_prefetch_part = 18735616, merge_max_block_size = 18940, old_parts_lifetime = 442., prefer_fetch_merged_part_size_threshold = 4414326261, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 8521168586, concurrent_part_removal_threshold = 65, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 95490, primary_key_compress_block_size = 58010), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:08.750659 [ 5620 ] {002cb3e0-1d8b-4cfd-ba02-9db04e354f31} TCPHandler: Code: 57. DB::Exception: Table test_13.ordinary_distinct already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:09.285340 [ 3237 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:09.470664 [ 3249 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:10.291231 [ 3264 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:10.473723 [ 3268 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:10.572851 [ 5629 ] {01cdfbaa-03bf-4587-8558-3da429c26ccc} 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.10521.altinitytest (altinity build)) (from [::1]:46380) (comment: 01930_optimize_skip_unused_shards_rewrite_in.sql) (in query: -- Int16, UInt16 select _shard_num, * from remote('127.{1..4}', view(select toInt16(id) id from data), toUInt16(id)) where id in (0, 1, 0x7fff) order by _shard_num, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:22:10.678934 [ 5629 ] {01cdfbaa-03bf-4587-8558-3da429c26ccc} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:22:10.892774 [ 4166 ] {f17d9786-500b-4e2a-a366-9532f38e9586} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:38986). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38986) (comment: 01930_optimize_skip_unused_shards_rewrite_in.sql) (in query: SELECT shardNum() AS `_shard_num`, `__table1`.`id` AS `id` FROM view(SELECT toInt16(`id`) AS `id` FROM `data`) AS `__table1` WHERE `__table1`.`id` IN tuple(0) ORDER BY shardNum() ASC, `__table1`.`id` 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1a1a4b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19bd1e 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:22:10.957574 [ 4166 ] {f17d9786-500b-4e2a-a366-9532f38e9586} 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]:38986). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:10.960520 [ 4166 ] {f17d9786-500b-4e2a-a366-9532f38e9586} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:38986). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1a1a4b 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19bd1e 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:22:10.964199 [ 4166 ] {f17d9786-500b-4e2a-a366-9532f38e9586} TCPHandler: Client has gone away. 2025.10.15 20:22:11.294749 [ 3280 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:11.477322 [ 3290 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:12.134195 [ 5617 ] {f09046d6-01a2-4d44-b932-8684e9e5d386} 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.10521.altinitytest (altinity build)) (from [::1]:57994) (comment: 00804_test_alter_compression_codecs.sql) (in query: INSERT INTO store_of_hash_00804 SELECT sum(cityHash64(*)) FROM large_alter_table_00804;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d356ec7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:22:12.162584 [ 5617 ] {f09046d6-01a2-4d44-b932-8684e9e5d386} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d356ec7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:22:12.297991 [ 3304 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:12.481243 [ 3309 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:13.229171 [ 5620 ] {dbc84ffd-ddea-49da-86d8-54a039ee5272} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=0): (while reading column StartDate): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_1_1_0/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 62442): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58752) (comment: 00041_aggregating_materialized_view.sql) (in query: INSERT INTO test.visits_null SELECT CounterID, StartDate, Sign, UserID FROM test.visits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ea3a9 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&) @ 0x000000002c80f3d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c80a315 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c80994b 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>>&) @ 0x000000002c80aafa 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de76ab4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:22:13.244938 [ 5620 ] {dbc84ffd-ddea-49da-86d8-54a039ee5272} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=0): (while reading column StartDate): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_1_1_0/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 62442): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ea3a9 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&) @ 0x000000002c80f3d4 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c80a315 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c80994b 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>>&) @ 0x000000002c80aafa 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de76ab4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:22:13.302710 [ 3325 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:13.485552 [ 3331 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:14.305391 [ 2852 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:14.488797 [ 2855 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:15.316889 [ 2867 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:15.497648 [ 2873 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:15.705786 [ 5620 ] {8599dda8-050d-483b-85b3-c7bfc9f92184} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58784) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:22:15.717965 [ 5620 ] {8599dda8-050d-483b-85b3-c7bfc9f92184} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:22:16.320527 [ 2891 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:16.500383 [ 2904 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:16.731901 [ 2764 ] {bb15f26b-7061-4cf8-9fd8-4787c5a93c5a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43916) (comment: 00080_array_join_and_union.sql) (in query: SELECT count() FROM (SELECT Goals.ID FROM test.visits ARRAY JOIN Goals WHERE CounterID = 842440 LIMIT 10 UNION ALL SELECT Goals.ID FROM test.visits ARRAY JOIN Goals WHERE CounterID = 842440 LIMIT 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:22:16.752135 [ 2764 ] {bb15f26b-7061-4cf8-9fd8-4787c5a93c5a} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c659d20 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) @ 0x000000002de484fd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:22:17.326305 [ 2913 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:17.396330 [ 3769 ] {01ca3836-1022-4465-a47d-d3e38570bced} executeQuery: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_15/s1/local_t_l5ydey already contains some data and it does not look like Replicated database path. (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58776) (comment: 02400_create_table_on_cluster_normalization.sql) (in query: -- Correct error code if creating database with the same path as table has create database local_t_l5ydey engine=Replicated('/clickhouse/tables/test_' || currentDatabase() || '/{shard}/local_t_l5ydey', '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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:604: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x0000000027d4d0d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d44e24 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 7. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 8. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:22:17.411126 [ 3769 ] {01ca3836-1022-4465-a47d-d3e38570bced} TCPHandler: Code: 36. DB::Exception: Cannot add new database replica: provided path /clickhouse/tables/test_test_15/s1/local_t_l5ydey already contains some data and it does not look like Replicated database 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:604: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x0000000027d4d0d3 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d44e24 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d4f631 7. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e1ae2 8. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192ac7 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:22:17.503641 [ 2916 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:18.329613 [ 2935 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:18.507035 [ 2944 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:19.332265 [ 2953 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:19.511745 [ 2961 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:20.338619 [ 2976 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:20.526199 [ 2981 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:21.342194 [ 2994 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:21.530772 [ 2997 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:21.782797 [ 3769 ] {22ca46c1-1e8f-4729-8f85-31672a7c1f9b} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime 2024-040: Cannot parse DateTime from String: In scope SELECT * FROM pv(timestamp_param = toDateTime('2024-040')). (CANNOT_PARSE_DATETIME) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43954) (comment: 03146_parameterized_view_with_date.sql) (in query: select * from pv (timestamp_param=toDateTime('2024-040'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char (&) [19]) @ 0x000000001aee7314 4. ./build_docker/./src/IO/ReadHelpers.cpp:1495: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001aee696f 5. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b137203 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b109d04 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4547: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028371ecf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:22:21.791401 [ 3769 ] {22ca46c1-1e8f-4729-8f85-31672a7c1f9b} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime 2024-040: Cannot parse DateTime from String: In scope SELECT * FROM pv(timestamp_param = toDateTime('2024-040')). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char (&) [19]) @ 0x000000001aee7314 4. ./build_docker/./src/IO/ReadHelpers.cpp:1495: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000001aee696f 5. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b137203 6. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b109d04 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4547: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x0000000028371ecf 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdea4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:22:22.355732 [ 3011 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:22.535382 [ 3017 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:23.359398 [ 3033 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:23.538694 [ 3038 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:24.362406 [ 3052 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:24.541392 [ 3050 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:25.364793 [ 3067 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:25.544288 [ 3069 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:25.868126 [ 3769 ] {0db2fbb0-d25b-4497-8e64-a6cfceb1437a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44010) (comment: 03232_pr_not_ready_set.sql) (in query: SELECT is_initial_query, count() AS c, replaceRegexpAll(query, '_data_(\\d+)_(\\d+)', '_data_') AS query FROM system.query_log WHERE (event_date >= yesterday()) AND (type = 'QueryFinish') AND (ignore(54, 0, ignore('QueryFinish', 11, toLowCardinality(toLowCardinality(11)), 11, 11, 11), 'QueryFinish', materialize(11), toUInt128(11)) IN ( SELECT query_id FROM system.query_log WHERE (current_database = currentDatabase()) AND (event_date >= yesterday()) AND (type = 'QueryFinish') AND (query LIKE '-- Parallel inner query alone%') )) GROUP BY is_initial_query, query ORDER BY is_initial_query ASC, c ASC, query ASC SETTINGS allow_experimental_parallel_reading_from_replicas=1, max_parallel_replicas=3, cluster_for_parallel_replicas='test_cluster_one_shard_three_replicas_localhost', parallel_replicas_for_non_replicated_merge_tree=1, parallel_replicas_min_number_of_rows_per_replica=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002defb871 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 22. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 23. ./build_docker/./src/Interpreters/PreparedSets.cpp:186: DB::FutureSetFromSubquery::buildSetInplace(std::shared_ptr const&) @ 0x00000000295e9fa7 24. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:0: DB::VirtualColumnUtils::buildSetsForDAG(DB::ActionsDAG const&, std::shared_ptr const&) @ 0x000000002bdd2dc3 25. ./contrib/llvm-project/libcxx/include/new:246: DB::VirtualColumnUtils::buildFilterExpression(DB::ActionsDAG, std::shared_ptr) @ 0x000000002bdd2f8b 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByVirtualColumns(std::shared_ptr const&, DB::MergeTreeData const&, std::vector, std::allocator>> const&, DB::ActionsDAG const*, std::shared_ptr) @ 0x000000002c6545a9 27. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1506: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002de4a881 28. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1685: 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) @ 0x000000002de46886 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 30. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000002de45c5e 31. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002946eb43 2025.10.15 20:22:25.879148 [ 3769 ] {0db2fbb0-d25b-4497-8e64-a6cfceb1437a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac6d2 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002defb871 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 22. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 23. ./build_docker/./src/Interpreters/PreparedSets.cpp:186: DB::FutureSetFromSubquery::buildSetInplace(std::shared_ptr const&) @ 0x00000000295e9fa7 24. ./build_docker/./src/Storages/VirtualColumnUtils.cpp:0: DB::VirtualColumnUtils::buildSetsForDAG(DB::ActionsDAG const&, std::shared_ptr const&) @ 0x000000002bdd2dc3 25. ./contrib/llvm-project/libcxx/include/new:246: DB::VirtualColumnUtils::buildFilterExpression(DB::ActionsDAG, std::shared_ptr) @ 0x000000002bdd2f8b 26. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByVirtualColumns(std::shared_ptr const&, DB::MergeTreeData const&, std::vector, std::allocator>> const&, DB::ActionsDAG const*, std::shared_ptr) @ 0x000000002c6545a9 27. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1506: DB::buildIndexes(std::optional&, DB::ActionsDAG const*, DB::MergeTreeData const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002de4a881 28. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1685: 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) @ 0x000000002de46886 29. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 30. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x000000002de45c5e 31. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x000000002946eb43 2025.10.15 20:22:26.367107 [ 3094 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:26.547162 [ 3104 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:27.369474 [ 3127 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:27.549208 [ 3130 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:27.675058 [ 3445 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_10} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:27.685568 [ 3445 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_10} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:28.371622 [ 3160 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:28.626892 [ 3165 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:28.748350 [ 3437 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_18} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:28.754927 [ 3437 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_18} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:29.375267 [ 3190 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:29.629221 [ 3203 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:29.890203 [ 3434 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_26} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:29.902345 [ 3434 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_26} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:30.099357 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_28} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:30.104841 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_28} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:30.378442 [ 3229 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:30.423622 [ 3446 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_30} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:30.429084 [ 3446 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_30} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:30.631816 [ 3233 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:31.381193 [ 3258 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:31.459199 [ 4166 ] {2cc95c27-b132-4475-b861-9575806314af} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52950) (comment: 02868_select_support_from_keywords.sql) (in query: drop table test_view;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:22:31.465502 [ 4166 ] {2cc95c27-b132-4475-b861-9575806314af} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:22:31.635002 [ 3268 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:31.759438 [ 3715 ] {6fa4ead2-7e0f-49a1-afba-500c2d6be37e} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37610) (comment: 02868_select_support_from_keywords.sql) (in query: DROP DATABASE IF EXISTS test_bqry7tlh ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 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>>>&) @ 0x00000000291fb9cc 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:22:31.854487 [ 3715 ] {6fa4ead2-7e0f-49a1-afba-500c2d6be37e} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 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>>>&) @ 0x00000000291fb9cc 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:31.904816 [ 3449 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_39} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:31.907491 [ 3449 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_39} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:32.300301 [ 3439 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_41} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:32.302780 [ 3439 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_41} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:32.385636 [ 3292 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:32.390141 [ 3291 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:32.637233 [ 3302 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:33.352329 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_46} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:33.371015 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_46} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:33.388698 [ 3324 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:33.641886 [ 3334 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:33.660317 [ 3769 ] {2d7f3585-fc7c-42d0-ac25-1dfb2792b836} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52962) (comment: 03039_dynamic_aggregating_merge_tree.sh) (in query: optimize table test final), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 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) @ 0x000000002cbd57b4 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) @ 0x000000002cbe0279 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be0f6e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:22:33.682349 [ 3769 ] {2d7f3585-fc7c-42d0-ac25-1dfb2792b836} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 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) @ 0x000000002cbd57b4 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) @ 0x000000002cbe0279 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be0f6e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:22:34.391284 [ 2854 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:34.619383 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_54} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:34.621407 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_54} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:34.652655 [ 2843 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:34.803245 [ 3448 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_54} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:34.805776 [ 3448 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_54} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=12, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:35.346380 [ 3449 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_57} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:35.348387 [ 3449 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_57} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:35.393965 [ 2880 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:35.656164 [ 2889 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:36.401162 [ 2910 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:36.658831 [ 2924 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:37.404377 [ 2947 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:37.556520 [ 3435 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_71} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:37.568592 [ 3435 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_71} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:37.661934 [ 2951 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:37.923141 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_73} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:37.957168 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_73} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:38.106444 [ 4166 ] {aa0f2e02-140a-4be1-a34b-8b6ce92fdcd4} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42690) (comment: 02457_csv_parse_date_out_of_range.sh) (in query: DROP DATABASE IF EXISTS test_d26m6qho ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:22:38.109155 [ 4166 ] {aa0f2e02-140a-4be1-a34b-8b6ce92fdcd4} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:38.229408 [ 3446 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_75} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:38.231526 [ 3446 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_75} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:38.406940 [ 2976 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:38.673662 [ 2982 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:39.409174 [ 3002 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:39.636283 [ 3448 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_88} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:39.648629 [ 3448 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_88} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:39.676044 [ 3013 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:40.316385 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_93} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:40.322555 [ 3443 ] {15486a59-e158-4344-824c-c7d8d99032cd::all_1_1_0_93} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=13, jobs=13). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:40.411909 [ 3033 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:40.678533 [ 3040 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:41.414068 [ 3064 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:41.681319 [ 3070 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:42.223265 [ 3445 ] {b5a4a975-c283-45a3-8ae8-bc042376b0e5::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:42.225457 [ 3445 ] {b5a4a975-c283-45a3-8ae8-bc042376b0e5::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:42.417383 [ 3096 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:42.538129 [ 3769 ] {1a2b1d00-6e6a-4111-87dc-1104d8f52ddf} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54976) (comment: 01900_kill_mutation_parallel_long.sh) (in query: alter table data_01900_2 update s = 'bar_1' where 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, String&, String&) @ 0x000000002c777626 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c777370 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbc6be5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbc87e9 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917863c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:22:42.549769 [ 3769 ] {1a2b1d00-6e6a-4111-87dc-1104d8f52ddf} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutation 'mutation_2.txt' with part 'all_1_1_0' reason: 'Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, String&, String&) @ 0x000000002c777626 4. ./build_docker/./src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x000000002c777370 5. ./build_docker/./src/Storages/StorageMergeTree.cpp:0: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x000000002cbc6be5 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageMergeTree::mutate(DB::MutationCommands const&, std::shared_ptr) @ 0x000000002cbc87e9 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917863c 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:22:42.683756 [ 3115 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:43.018718 [ 2764 ] {88c47d1c-6095-457c-b819-c25a7eaa8321} executeQuery: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55000) (comment: 01474_bad_global_join.sql) (in query: SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000283cb2c0 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5125: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c3ff5 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdece 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:22:43.024220 [ 2764 ] {88c47d1c-6095-457c-b819-c25a7eaa8321} TCPHandler: Code: 47. DB::Exception: JOIN GLOBAL LEFT JOIN ... USING (id) using identifier 'id' cannot be resolved from right table expression. In scope SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN numbers(100) AS t USING (id). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&) @ 0x00000000283cb2c0 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5125: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c3ff5 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283bdece 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e689 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:22:43.420364 [ 3179 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:43.607624 [ 2764 ] {5c1060c7-7b8a-4c80-ab2e-2999be0c458d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55000) (comment: 01474_bad_global_join.sql) (in query: SELECT uniq(d.val) FROM dist_table AS d GLOBAL LEFT JOIN local_table AS t USING id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:43.635875 [ 2764 ] {5c1060c7-7b8a-4c80-ab2e-2999be0c458d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:43.686774 [ 3198 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:44.423423 [ 3235 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:44.689563 [ 3234 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:44.928592 [ 5086 ] {0cb2b25a-0118-4a11-9223-dca82d080f24} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:44.951131 [ 5618 ] {0cb2b25a-0118-4a11-9223-dca82d080f24} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): (in file/uri 02661_read_from_archive_test_sxipylcy_tzst_data1.csv): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55062) (comment: 02661_read_from_archive_tzst.sh) (in query: SELECT * FROM 02661_archive_table ORDER BY 1, 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:22:44.962945 [ 5618 ] {0cb2b25a-0118-4a11-9223-dca82d080f24} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): (in file/uri 02661_read_from_archive_test_sxipylcy_tzst_data1.csv): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:22:45.426261 [ 3255 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:45.692039 [ 3262 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:46.429073 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:46.538601 [ 4166 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:46.693944 [ 3284 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:47.432620 [ 3282 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:47.697454 [ 3300 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:48.431226 [ 3769 ] {52f63aac-98fc-45de-8a6f-6c0b32bc4335} executeQuery: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39616) (comment: 02661_read_from_archive_tzst.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_sxipylcy_tzst_archive{1..2}.tzst :: 02661_read_from_archive_test_sxipylcy_tzst_data1.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:48.435632 [ 3316 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:48.440657 [ 3769 ] {52f63aac-98fc-45de-8a6f-6c0b32bc4335} TCPHandler: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:48.699930 [ 3320 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:49.438518 [ 3335 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:49.502416 [ 5072 ] {ff88ffc4-8a71-4f34-9798-9642ab769adb} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:49.533250 [ 3769 ] {ff88ffc4-8a71-4f34-9798-9642ab769adb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): (in file/uri 02661_read_from_archive_test_sxipylcy_tzst_data1.csv): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39632) (comment: 02661_read_from_archive_tzst.sh) (in query: SELECT * FROM 02661_archive_table ORDER BY 1, 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:22:49.536870 [ 2764 ] {13de6437-0500-4d21-a0a2-c26cb81b1f42} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39620) (comment: 02784_move_all_conditions_to_prewhere_analyzer_asan.sql) (in query: SELECT c1, c2 FROM t_02784 WHERE c1 = 0 AND c2 = 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:49.549248 [ 3769 ] {ff88ffc4-8a71-4f34-9798-9642ab769adb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): (in file/uri 02661_read_from_archive_test_sxipylcy_tzst_data1.csv): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:22:49.550176 [ 2764 ] {13de6437-0500-4d21-a0a2-c26cb81b1f42} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:49.702390 [ 2831 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:50.441239 [ 2838 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:50.707173 [ 2855 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:51.443817 [ 2873 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:51.710378 [ 2870 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:52.446457 [ 2890 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:52.743647 [ 2896 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:52.919005 [ 3723 ] {b741a9d6-78f3-4cb4-887d-0c1feff7190e} executeQuery: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39724) (comment: 02661_read_from_archive_tzst.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_sxipylcy_tzst_archive{1,2}.tzst :: 02661_read_from_archive_test_sxipylcy_tzst_data{1,3}.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:52.935065 [ 3723 ] {b741a9d6-78f3-4cb4-887d-0c1feff7190e} TCPHandler: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:53.449270 [ 2912 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:53.746915 [ 2921 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:54.453318 [ 2928 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:54.749226 [ 2942 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:55.470138 [ 2953 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:55.753057 [ 2960 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:56.472271 [ 2969 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:56.580008 [ 4168 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:56.757518 [ 2982 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:57.200241 [ 2764 ] {b65bbf2d-44b8-4fea-9ca3-c9e27fdbe41a} executeQuery: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53578) (comment: 02661_read_from_archive_tzst.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_sxipylcy_tzst_archive3.tzst :: 02661_read_from_archive_test_sxipylcy_tzst_data*.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:57.211679 [ 2764 ] {b65bbf2d-44b8-4fea-9ca3-c9e27fdbe41a} TCPHandler: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:57.474363 [ 2995 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:57.761128 [ 3007 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:58.478697 [ 3018 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:58.763767 [ 3025 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:59.482049 [ 3037 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:22:59.699072 [ 3769 ] {f20ba616-fb80-4075-877b-7ac8d1d76056} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39660) (comment: 03174_exact_rows_before_aggregation.sql) (in query: create table test (i int) engine MergeTree order by i;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:59.706340 [ 3769 ] {f20ba616-fb80-4075-877b-7ac8d1d76056} TCPHandler: Code: 57. DB::Exception: Table test_15.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:22:59.766311 [ 3034 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:00.484940 [ 3050 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:00.769328 [ 3059 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:01.487240 [ 3067 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:01.772432 [ 3072 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:01.827025 [ 2766 ] {44eb40bb-a363-4311-a1f4-fa660e81c65c} executeQuery: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53694) (comment: 02661_read_from_archive_tzst.sh) (in query: CREATE TABLE 02661_archive_table Engine=File('CSV', '/var/lib/clickhouse/user_files/02661_read_from_archive_test_sxipylcy_tzst_archive*.tzst :: *.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:01.836934 [ 2766 ] {44eb40bb-a363-4311-a1f4-fa660e81c65c} TCPHandler: Code: 57. DB::Exception: Table test_sxipylcy.`02661_archive_table` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:02.489843 [ 3079 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:02.570934 [ 5073 ] {14297c54-a6ce-417a-ad37-c64e22239a70} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:02.585672 [ 2766 ] {14297c54-a6ce-417a-ad37-c64e22239a70} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): (in file/uri 02661_read_from_archive_test_sxipylcy_tzst_data1.csv): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53724) (comment: 02661_read_from_archive_tzst.sh) (in query: SELECT * FROM 02661_archive_table ORDER BY 1, 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:23:02.592119 [ 2766 ] {14297c54-a6ce-417a-ad37-c64e22239a70} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0): (in file/uri 02661_read_from_archive_test_sxipylcy_tzst_data1.csv): While executing ParallelParsingBlockInputFormat: While executing File. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d70a4c5 7. ./build_docker/./src/Processors/Formats/Impl/ParallelParsingInputFormat.cpp:0: DB::ParallelParsingInputFormat::segmentatorThreadFunction(std::shared_ptr) @ 0x000000002d706dbd 8. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002d70ffb2 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 2025.10.15 20:23:02.775430 [ 3089 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:03.492915 [ 3109 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:03.779832 [ 3106 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:04.501550 [ 3120 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:04.787625 [ 3135 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:05.503869 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:05.790157 [ 3156 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:06.506175 [ 3161 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:06.793024 [ 3175 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:07.508561 [ 3182 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:07.796591 [ 3185 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:08.511912 [ 3201 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:08.799850 [ 3208 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:09.515218 [ 3223 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:09.803081 [ 3227 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:10.518375 [ 3233 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:10.806446 [ 3241 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:11.521179 [ 3255 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:11.809702 [ 3250 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:11.995860 [ 3906 ] {265ef4d0-3aad-44f4-b40b-cce8251708af} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54888) (comment: 00617_array_in.sql) (in query: SELECT count(*) FROM test_array_ops where arr > CAST([10, -20] AS Array(Nullable(Int64)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:23:12.000208 [ 3906 ] {265ef4d0-3aad-44f4-b40b-cce8251708af} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:23:12.365821 [ 2766 ] {50363438-8afd-4f74-8e4d-78e605176d04} 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.10521.altinitytest (altinity build)) (from [::1]:50216) (comment: 00617_array_in.sql) (in query: DROP DATABASE IF EXISTS test_c93w7gnp ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:23:12.369426 [ 2766 ] {50363438-8afd-4f74-8e4d-78e605176d04} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:12.523999 [ 3273 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:12.812951 [ 3279 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:13.526558 [ 3295 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:13.816293 [ 3299 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:14.206617 [ 3305 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:14.529529 [ 3312 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:14.819861 [ 3315 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:15.532325 [ 3325 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:15.823218 [ 3334 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:16.209708 [ 2839 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:16.535073 [ 2850 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:16.756874 [ 2764 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:16.826197 [ 2852 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:17.540878 [ 2857 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:17.832113 [ 2846 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:18.151087 [ 2862 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:18.535517 [ 3443 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {24310d89-f4f4-4694-b8de-dac7140488d3::202510_1_52_17}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:18.543157 [ 2870 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:18.835707 [ 2872 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:18.988021 [ 3439 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {24310d89-f4f4-4694-b8de-dac7140488d3::202510_1_52_17}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:19.545777 [ 2904 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:19.840180 [ 2905 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:20.549083 [ 2920 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:20.844096 [ 2932 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:21.552163 [ 2943 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:21.856026 [ 2946 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:21.874607 [ 3896 ] {d98ffb3e-5a6c-41b5-8550-565f9f459d34} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56248) (comment: 02494_query_cache_eligible_queries.sql) (in query: SELECT COUNT(*) FROM system.query_cache;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:21.879185 [ 3896 ] {d98ffb3e-5a6c-41b5-8550-565f9f459d34} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:22.052345 [ 3906 ] {e6512718-5efd-4449-b89a-efeb651922eb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41850) (comment: 02494_query_cache_eligible_queries.sql) (in query: DROP DATABASE IF EXISTS test_g7essr57 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:23:22.127605 [ 3906 ] {e6512718-5efd-4449-b89a-efeb651922eb} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:22.202556 [ 3896 ] {ce46b0b8-1bf1-45c4-b973-cfca7c4a82bb} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41854) (comment: 02494_query_cache_eligible_queries.sql) (in query: DROP DATABASE IF EXISTS test_g7essr57 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:23:22.207227 [ 3896 ] {ce46b0b8-1bf1-45c4-b973-cfca7c4a82bb} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:22.326945 [ 3906 ] {7f6b0bc6-b3a0-4fee-a74d-6442c7c52be0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41870) (comment: 02494_query_cache_eligible_queries.sql) (in query: DROP DATABASE IF EXISTS test_g7essr57 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:23:22.330068 [ 3906 ] {7f6b0bc6-b3a0-4fee-a74d-6442c7c52be0} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:22.554926 [ 2965 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:22.858362 [ 2973 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:23.557980 [ 2985 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:23.860923 [ 2990 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:24.560798 [ 3004 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:24.863863 [ 3014 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:25.563711 [ 3022 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:25.866673 [ 3021 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:26.566311 [ 3047 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:26.869640 [ 3057 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:27.569085 [ 3066 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:27.872361 [ 3073 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:27.928910 [ 5620 ] {e42becb2-f8d7-4224-9593-ebd5fa41b347} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53324) (comment: 00899_long_attach_memory_limit.sql) (in query: INSERT INTO index_memory SELECT * FROM system.numbers LIMIT 5000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d355df7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d1870e3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:23:27.935572 [ 5620 ] {e42becb2-f8d7-4224-9593-ebd5fa41b347} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d355df7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d1870e3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:23:28.571642 [ 3089 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:28.879608 [ 3098 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:29.574898 [ 3107 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:29.883801 [ 3113 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:30.260419 [ 3896 ] {a9bf0382-7138-45b7-973e-aa5af7226773} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress, the number of elements in the compressed data (65) is not equal to the expected number of elements in the decompressed data (1). (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7b4ba 4. ./build_docker/./src/Compression/CompressionCodecT64.cpp:589: DB::CompressionCodecT64::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x00000000277a6aee 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x00000000277fb969 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:27: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x0000000027761fc7 7. DB::ReadBuffer::next() @ 0x000000000b52aaeb 8. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000026b4bdb5 9. DB::ReadBuffer::next() @ 0x000000000b52aaeb 10. ./src/IO/ReadBuffer.h:106: DB::ConcatReadBuffer::nextImpl() @ 0x00000000284b9499 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. ./src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b42e74 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:30.577647 [ 3121 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:30.886794 [ 3130 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:31.579994 [ 3157 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:31.890182 [ 3167 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:32.102440 [ 3906 ] {7dde8525-2dc8-4811-9baa-9bd46bc55667} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56318) (comment: 02015_division_by_nullable.sql) (in query: SELECT intDiv(materialize(1), CAST(materialize(NULL), 'Nullable(Float32)'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:32.107697 [ 3906 ] {7dde8525-2dc8-4811-9baa-9bd46bc55667} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=727). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:32.582332 [ 3175 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:32.892916 [ 3182 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:33.585306 [ 3200 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:33.895733 [ 3213 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:34.619857 [ 3228 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:34.898392 [ 3240 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:35.222969 [ 3447 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2d6955c1-12a8-48e1-8c31-9252f5a6aaec::202510_1_45_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:35.536761 [ 3439 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2d6955c1-12a8-48e1-8c31-9252f5a6aaec::202510_1_45_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:35.628541 [ 3250 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:35.901050 [ 3271 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:36.631806 [ 3280 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:36.904608 [ 3292 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:37.634973 [ 3306 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:37.907610 [ 3314 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:38.637923 [ 2823 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:38.910744 [ 2828 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:39.640612 [ 2852 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:39.913770 [ 2856 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:40.643737 [ 2869 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:40.916352 [ 2876 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:41.646407 [ 2889 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:41.919611 [ 2894 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:42.649464 [ 2918 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:42.901538 [ 2766 ] {b1ed7c55-7e18-4310-af3b-4bb5d6a1a82f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53336) (comment: 01676_range_hashed_dictionary.sql) (in query: DROP DICTIONARY range_dictionary_nullable;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:23:42.920239 [ 2766 ] {b1ed7c55-7e18-4310-af3b-4bb5d6a1a82f} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:23:42.924002 [ 2930 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:43.652398 [ 2941 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:43.931837 [ 2949 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:44.304693 [ 4166 ] {40573010-7f77-4258-8436-90fcf287059d} executeQuery: Code: 264. DB::Exception: Table 'test_15.testJoinTable (940116ae-b158-47a1-bc21-0c33dbeab662)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37034) (comment: 01050_engine_join_crash.sql) (in query: SELECT * FROM (SELECT * FROM numbers(10)) js1 INNER JOIN testJoinTable USING number;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000002b8360a3 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a9b2e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:23:44.315127 [ 4166 ] {40573010-7f77-4258-8436-90fcf287059d} TCPHandler: Code: 264. DB::Exception: Table 'test_15.testJoinTable (940116ae-b158-47a1-bc21-0c33dbeab662)' has incompatible type of JOIN. (INCOMPATIBLE_TYPE_OF_JOIN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/StorageJoin.cpp:235: DB::StorageJoin::getJoinLocked(std::shared_ptr, std::shared_ptr, std::vector> const&) const @ 0x000000002b8360a3 5. ./build_docker/./src/Planner/PlannerJoins.cpp:0: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294a9b2e 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 8. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 9. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 10. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:23:44.655155 [ 2963 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:44.934534 [ 2970 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:45.657264 [ 2982 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:45.712928 [ 4166 ] {8a976949-8b87-400d-899f-f84ddcbd8e47} 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.10521.altinitytest (altinity build)) (from [::1]:37034) (comment: 01050_engine_join_crash.sql) (in query: CREATE TABLE transaction (`id` Int32, `value` Float64, `master_id` Int32) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 60905, min_bytes_for_wide_part = 731386722, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 123718435, compact_parts_max_granules_to_buffer = 157, compact_parts_merge_max_bytes_to_prefetch_part = 31179627, merge_max_block_size = 14103, old_parts_lifetime = 433., 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 = 1731108763, index_granularity_bytes = 29775119, concurrent_part_removal_threshold = 86, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 17161, primary_key_compress_block_size = 26421), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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>) @ 0x000000002cbb7308 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>&&) @ 0x000000002cbb5eda 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac598 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:23:45.731497 [ 4166 ] {8a976949-8b87-400d-899f-f84ddcbd8e47} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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>) @ 0x000000002cbb7308 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>&&) @ 0x000000002cbb5eda 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac598 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:23:45.937139 [ 2996 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:46.645414 [ 3906 ] {165f8f4b-bd87-46de-bb10-4f694f23fd97} executeQuery: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34326) (comment: 01777_map_populate_series_ubsan.sql) (in query: -- Should correctly throw exception about overflow: SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001abbe566 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001abbd1dc 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a841748 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:23:46.655972 [ 3906 ] {165f8f4b-bd87-46de-bb10-4f694f23fd97} TCPHandler: Code: 128. DB::Exception: Function mapPopulateSeries too large array size in the result: In scope SELECT mapPopulateSeries([-9223372036854775808, toUInt32(2)], [toUInt32(1023), -1]). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. void DB::FunctionMapPopulateSeries::executeImplTyped(COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::immutable_ptr const&, COW::mutable_ptr, COW::mutable_ptr, COW::mutable_ptr) const @ 0x000000001abbe566 5. auto DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator(), DB::DataTypeNumber>>(auto const&) const @ 0x000000001abbd1dc 6. DB::FunctionMapPopulateSeries::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a841748 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 10. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:23:46.660866 [ 3010 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:46.863846 [ 5620 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:46.939594 [ 3020 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:47.666265 [ 3027 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:47.942950 [ 3036 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:48.669191 [ 3056 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:48.945248 [ 3063 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:48.978052 [ 3906 ] {d0a57d3c-7695-4256-87d6-635a2954403a} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34344) (comment: 02188_parser_dictionary_primary_key.sql) (in query: DROP DICTIONARY 02188_test_dictionary_simple_primary_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:23:48.983686 [ 3906 ] {d0a57d3c-7695-4256-87d6-635a2954403a} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:23:49.334847 [ 5620 ] {07d7b697-9177-48e2-8a30-08b9d0bd1941} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51418) (comment: 02188_parser_dictionary_primary_key.sql) (in query: DROP DATABASE IF EXISTS test_3z55e3zu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 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>>>&) @ 0x00000000291fb9cc 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:23:49.347181 [ 5620 ] {07d7b697-9177-48e2-8a30-08b9d0bd1941} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 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>>>&) @ 0x00000000291fb9cc 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:49.678381 [ 3101 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:49.948345 [ 3109 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:50.402750 [ 4166 ] {a278146e-1fac-40ea-9599-876b2e96f601} executeQuery: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34364) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: CREATE TABLE t_row_exists (`a` int, `_row_exists` int) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 16752, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 98, min_bytes_for_full_part_storage = 457406546, compact_parts_max_bytes_to_buffer = 400065252, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 31111113, merge_max_block_size = 1583, old_parts_lifetime = 95., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 97, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 25923390, concurrent_part_removal_threshold = 94, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 32249, primary_key_compress_block_size = 69014), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:934: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000291a99fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bde6c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:23:50.412982 [ 4166 ] {a278146e-1fac-40ea-9599-876b2e96f601} TCPHandler: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:934: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000291a99fb 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291bde6c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:23:50.680943 [ 3119 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:50.951202 [ 3122 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:51.091814 [ 4166 ] {4e0f8e4d-6010-4cb2-b08f-8fb1c74b2f38} executeQuery: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34364) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists add column _row_exists int;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1343: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e489 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.095213 [ 4166 ] {4e0f8e4d-6010-4cb2-b08f-8fb1c74b2f38} TCPHandler: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1343: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e489 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.148224 [ 3769 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f837f2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1b228d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1982c2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d185b41 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.222553 [ 4166 ] {bd846391-bf0f-4826-aeb1-49b1562b7524} executeQuery: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34364) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists rename column b to _row_exists;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1568: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60d764 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.229225 [ 4166 ] {bd846391-bf0f-4826-aeb1-49b1562b7524} TCPHandler: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1568: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60d764 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.403193 [ 4166 ] {dc3152ca-ef80-4b1b-aceb-d33bcffe3f35} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34364) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists rename column _row_exists to 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e06e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.421151 [ 4166 ] {dc3152ca-ef80-4b1b-aceb-d33bcffe3f35} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1557: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e06e 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.594304 [ 4166 ] {8ffb84d5-6bf0-4931-a8cd-5700cc2f52a1} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34364) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists drop column _row_exists;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e827 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.599831 [ 4166 ] {8ffb84d5-6bf0-4931-a8cd-5700cc2f52a1} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e827 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.668978 [ 4166 ] {2367f75c-88a4-4731-bbe2-e0455cec8d22} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34364) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: alter table t_row_exists drop column unknown_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e827 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.674470 [ 4166 ] {2367f75c-88a4-4731-bbe2-e0455cec8d22} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b60e827 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291780f2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:23:51.724580 [ 3150 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:51.954705 [ 3152 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:52.582336 [ 4166 ] {b1f5444d-577f-4112-9802-ee1a4bdec77d} executeQuery: Code: 57. DB::Exception: Table test_lw6rl61p.t_row_exists already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34364) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (in query: create table t_row_exists(a int, b int) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:52.591043 [ 4166 ] {b1f5444d-577f-4112-9802-ee1a4bdec77d} TCPHandler: Code: 57. DB::Exception: Table test_lw6rl61p.t_row_exists already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:23:52.727257 [ 3172 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:52.958316 [ 3179 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:53.610372 [ 4166 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f837f2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1b228d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1982c2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d185b41 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:23:53.731053 [ 3196 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:53.962356 [ 3203 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:54.739156 [ 3219 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:54.965106 [ 3221 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:55.747273 [ 3243 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:55.967984 [ 3251 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:56.751816 [ 3271 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:56.970598 [ 3277 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:57.754498 [ 3291 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:57.975216 [ 3297 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:58.757447 [ 3313 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:58.977597 [ 3314 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:59.760177 [ 3328 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:23:59.980420 [ 3331 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:00.762970 [ 2831 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:00.983382 [ 2837 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:01.765803 [ 2858 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:01.986392 [ 2857 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:02.030905 [ 3588 ] {} ExternalDictionariesLoader: Could not check if external dictionary '5aff4689-c081-4f1e-8f9a-95fa4a3916e2' was modified: Code: 60. DB::Exception: Unknown table expression identifier 'dict_invalidate' in scope SELECT max(last_time) FROM dict_invalidate. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:0: DB::ClickHouseDictionarySource::doInvalidateQuery(String const&) const @ 0x000000001b4d12b6 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:141: DB::ClickHouseDictionarySource::isModified() const @ 0x000000001b4cff60 17. ./src/Dictionaries/IDictionary.h:0: DB::IDictionary::isModified() const @ 0x000000001b64befd 18. ./build_docker/./src/Interpreters/ExternalLoader.cpp:669: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x000000002912a6f4 19. ./contrib/llvm-project/libcxx/include/__mutex_base:203: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x0000000029129b32 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000002912e13f 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:02.345808 [ 3884 ] {} ExternalDictionariesLoader: Could not update external dictionary '5aff4689-c081-4f1e-8f9a-95fa4a3916e2', leaving the previous version, next update is scheduled at 2025-10-15 20:24:07: Code: 60. DB::Exception: Unknown table expression identifier 'test_uuuzjlo7.dict_invalidate' in scope SELECT dummy, dummy AS two FROM test_uuuzjlo7.dict_invalidate. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:173: DB::ClickHouseDictionarySource::createStreamForQuery(String const&) @ 0x000000001b4cf010 16. ./build_docker/./src/Dictionaries/ClickHouseDictionarySource.cpp:115: DB::ClickHouseDictionarySource::loadAll() @ 0x000000001b4cedf5 17. DB::FlatDictionary::loadData() @ 0x000000001b6745f7 18. DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x000000001b67392a 19. std::shared_ptr std::allocate_shared[abi:v15007], DB::StorageID, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration const&, std::shared_ptr const&, void>(std::allocator const&, DB::StorageID&&, DB::DictionaryStructure const&, std::shared_ptr&&, DB::FlatDictionary::Configuration const&, std::shared_ptr const&) @ 0x000000001b6d3e1d 20. DB::FlatDictionary::clone() const @ 0x000000001b6bf8e3 21. ./build_docker/./src/Interpreters/ExternalLoader.cpp:0: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x000000002910b2e0 22. ./contrib/llvm-project/libcxx/include/__utility/pair.h:520: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x000000002910448a 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:359: ? @ 0x0000000029111c11 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:02.769091 [ 2861 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:02.997095 [ 2877 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:03.772103 [ 2899 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:04.000042 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:04.774696 [ 2924 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:05.068453 [ 2928 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:05.777874 [ 2945 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:06.070685 [ 2944 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:06.786725 [ 2963 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:07.073723 [ 2962 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:07.790110 [ 2981 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:08.076348 [ 2987 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:08.816377 [ 2995 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:09.084565 [ 3005 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:09.819592 [ 3018 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:10.095162 [ 3016 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:10.822643 [ 3042 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:11.098756 [ 3057 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:11.825586 [ 3075 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:12.106618 [ 3089 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:12.782194 [ 3436 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_102_117_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:12.828981 [ 3110 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:13.108534 [ 3123 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:13.832400 [ 3131 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:14.111362 [ 3138 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:14.268068 [ 4166 ] {7500d1fa-a9d6-48e4-a67b-dd34b329ed29} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49622) (comment: 00443_preferred_block_size_bytes.sh) (in query: SELECT count() FROM pbs PREWHERE s = 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 15. ./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) @ 0x000000002c80804a 16. ./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&) @ 0x000000002c5f5a66 17. ./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 @ 0x000000002c5ed5ee 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:24:14.293878 [ 4166 ] {7500d1fa-a9d6-48e4-a67b-dd34b329ed29} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 15. ./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) @ 0x000000002c80804a 16. ./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&) @ 0x000000002c5f5a66 17. ./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 @ 0x000000002c5ed5ee 18. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:24:14.836422 [ 3154 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:15.113894 [ 3162 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:15.519301 [ 3165 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:15.715393 [ 2764 ] {252d45d4-9164-434a-b67e-382adcf320f7} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55006) (comment: 01817_storage_buffer_parameters.sql) (in query: drop table buffer_01817;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:24:15.754461 [ 2764 ] {252d45d4-9164-434a-b67e-382adcf320f7} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:24:15.842360 [ 3169 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:16.116767 [ 3177 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:16.295682 [ 2764 ] {5bf0b33b-a7a0-418e-8b7c-630dc605babc} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55018) (in query: SET enable_analyzer = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:24:16.303451 [ 2764 ] {5bf0b33b-a7a0-418e-8b7c-630dc605babc} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:24:16.410475 [ 2766 ] {72e23aca-7262-42d6-b2c2-5c1694a5796c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55030) (in query: SET enable_analyzer = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:24:16.413820 [ 2766 ] {72e23aca-7262-42d6-b2c2-5c1694a5796c} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:24:16.844666 [ 3192 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:17.108699 [ 2764 ] {c9d27a6c-3a44-4be9-9671-96fbfd2465e3} executeQuery: Code: 1. DB::Exception: Experimental WINDOW VIEW feature is not supported in the current infrastructure for query analysis (the setting 'allow_experimental_analyzer'). (UNSUPPORTED_METHOD) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55018) (in query: CREATE WINDOW VIEW db_01059_event_hop_watch_strict_asc.wv ENGINE Memory WATERMARK=STRICTLY_ASCENDING AS SELECT count(a) AS count, hopEnd(wid) as w_end FROM db_01059_event_hop_watch_strict_asc.mt GROUP BY hop(timestamp, INTERVAL '2' SECOND, INTERVAL '3' SECOND, 'US/Samoa') AS wid;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1767: DB::StorageWindowView::throwIfWindowViewIsDisabled(std::shared_ptr) const @ 0x000000002cc8d96d 5. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:0: DB::StorageWindowView::StorageWindowView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel) @ 0x000000002cca78dd 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&, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002ccd06dc 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&) @ 0x000000002ccc0925 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 @ 0x000000002b782bf3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:24:17.112858 [ 2764 ] {c9d27a6c-3a44-4be9-9671-96fbfd2465e3} TCPHandler: Code: 1. DB::Exception: Experimental WINDOW VIEW feature is not supported in the current infrastructure for query analysis (the setting 'allow_experimental_analyzer'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:1767: DB::StorageWindowView::throwIfWindowViewIsDisabled(std::shared_ptr) const @ 0x000000002cc8d96d 5. ./build_docker/./src/Storages/WindowView/StorageWindowView.cpp:0: DB::StorageWindowView::StorageWindowView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel) @ 0x000000002cca78dd 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&, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002ccd06dc 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&) @ 0x000000002ccc0925 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 @ 0x000000002b782bf3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:24:17.119408 [ 3203 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:17.184598 [ 2764 ] {640bf22a-1780-4274-b881-798b77b81c16} executeQuery: Code: 60. DB::Exception: Table db_01059_event_hop_watch_strict_asc.wv does not exist. (UNKNOWN_TABLE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55018) (in query: WATCH db_01059_event_hop_watch_strict_asc.wv), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:66: DB::InterpreterWatchQuery::buildQueryPipeline() @ 0x0000000029c2e026 5. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::execute() @ 0x0000000029c2cbbd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:24:17.193862 [ 2764 ] {640bf22a-1780-4274-b881-798b77b81c16} TCPHandler: Code: 60. DB::Exception: Table db_01059_event_hop_watch_strict_asc.wv 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:66: DB::InterpreterWatchQuery::buildQueryPipeline() @ 0x0000000029c2e026 5. ./build_docker/./src/Interpreters/InterpreterWatchQuery.cpp:0: DB::InterpreterWatchQuery::execute() @ 0x0000000029c2cbbd 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:24:17.847562 [ 3210 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:18.122348 [ 3224 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:18.850195 [ 3246 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:19.124881 [ 3257 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:19.415442 [ 4166 ] {1c16f697-b148-4485-a54e-5a4c0c0e81bd} 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.10521.altinitytest (altinity build)) (from [::1]:55046) (in query: SELECT DISTINCT arrayJoin(extractAll(name, '[\\w_]{2,}')) AS res FROM (SELECT * FROM viewIfPermitted(SELECT name FROM system.functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_engines ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.formats ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.table_functions ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.data_type_families ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.merge_tree_settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.settings ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT keyword FROM system.keywords ELSE null('keyword String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT cluster FROM system.clusters ELSE null('cluster String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT macro FROM system.macros ELSE null('macro String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT policy_name FROM system.storage_policies ELSE null('policy_name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT concat(func.name, comb.name) AS x FROM system.functions AS func CROSS JOIN system.aggregate_function_combinators AS comb WHERE is_aggregate ELSE null('x String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT name FROM system.databases LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.tables LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.dictionaries LIMIT 10000 ELSE null('name String')) UNION ALL SELECT * FROM viewIfPermitted(SELECT DISTINCT name FROM system.columns LIMIT 10000 ELSE null('name String'))) WHERE notEmpty(res)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:24:19.425888 [ 4166 ] {1c16f697-b148-4485-a54e-5a4c0c0e81bd} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:24:19.853036 [ 3281 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:20.126989 [ 3283 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:20.856303 [ 3298 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:21.130098 [ 3313 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:21.860031 [ 3329 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:22.134032 [ 2822 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:22.863480 [ 2850 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:23.136937 [ 2854 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:23.866352 [ 2843 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:24.139706 [ 2863 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:24.869861 [ 2871 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:25.142751 [ 2883 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:25.870014 [ 5620 ] {d8014f51-abda-4071-9430-51a76f0af9ca} 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.10521.altinitytest (altinity build)) (from [::1]:55080) (comment: 01682_cache_dictionary_complex_key.sql) (in query: DROP DATABASE 01682_database_for_cache_dictionary;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:24:25.873526 [ 2901 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:25.884049 [ 5620 ] {d8014f51-abda-4071-9430-51a76f0af9ca} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:24:26.145069 [ 2897 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:26.876255 [ 2932 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:27.010131 [ 3896 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:27.147841 [ 2934 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:27.879359 [ 2957 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:28.150818 [ 2956 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:28.649468 [ 4166 ] {3c6b7657-83de-4985-a7c8-f54f606ab57e} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52620) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 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) @ 0x000000002b7a4802 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) @ 0x000000002946e6e2 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&) @ 0x000000002946217d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:24:28.653417 [ 4166 ] {3c6b7657-83de-4985-a7c8-f54f606ab57e} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 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) @ 0x000000002b7a4802 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) @ 0x000000002946e6e2 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&) @ 0x000000002946217d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:24:28.883745 [ 2971 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:29.154050 [ 2969 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:29.887871 [ 2991 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:30.156893 [ 3003 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:30.891896 [ 3011 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:31.159707 [ 3019 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:31.894786 [ 3032 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:32.162555 [ 3036 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:32.897636 [ 3043 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:33.165411 [ 3049 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:33.900285 [ 3078 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:34.169514 [ 3077 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:34.903378 [ 3100 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:35.172262 [ 3107 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:35.906007 [ 3122 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:36.175132 [ 3132 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:36.908866 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:37.178378 [ 3150 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:37.912928 [ 3155 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:38.180969 [ 3146 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:38.915811 [ 3181 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:39.183803 [ 3193 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:39.958964 [ 3206 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:40.186932 [ 3210 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:40.887548 [ 4166 ] {03555272-0d56-4641-85fb-89a53d7af56a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54642) (comment: 02378_analyzer_projection_names.sql) (in query: SELECT '--';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:24:40.893275 [ 4166 ] {03555272-0d56-4641-85fb-89a53d7af56a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:24:40.971964 [ 3227 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:41.189800 [ 3225 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:41.974889 [ 3245 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:42.192406 [ 3264 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:42.978022 [ 3281 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:43.195266 [ 3279 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:44.066688 [ 3301 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:44.198169 [ 3298 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:45.069834 [ 3320 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:45.200833 [ 3323 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:46.072732 [ 2832 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:46.203618 [ 2839 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:47.075821 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:47.206940 [ 2842 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:48.078968 [ 2843 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:48.209444 [ 2867 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:48.966702 [ 3442 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3b7b9d5c-f30c-4cec-915e-651025b581f7::202510_1_55_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:49.082187 [ 2878 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:49.212135 [ 2890 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:50.084884 [ 2906 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:50.215097 [ 2895 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:51.087710 [ 2918 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:51.217795 [ 2930 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:52.090846 [ 2942 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:52.220961 [ 2946 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:53.152143 [ 2956 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:53.224068 [ 2965 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:54.155299 [ 2975 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:54.226994 [ 2989 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:55.157986 [ 2997 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:55.229629 [ 3006 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:56.160706 [ 3026 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:56.232500 [ 3032 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:57.163584 [ 3057 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:57.238553 [ 3050 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:58.166337 [ 3078 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:58.241606 [ 3084 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:59.169487 [ 3093 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:24:59.252710 [ 3101 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:00.172256 [ 3110 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:00.255455 [ 3120 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:01.174776 [ 3138 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:01.258319 [ 3141 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:02.176997 [ 3153 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:02.261322 [ 3162 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:03.179973 [ 3177 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:03.264517 [ 3178 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:04.183160 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:04.276764 [ 3206 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:05.187568 [ 3220 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:05.280183 [ 3227 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:06.191001 [ 3236 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:06.283467 [ 3246 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:07.193892 [ 3264 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:07.287217 [ 3263 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:08.196547 [ 3287 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:08.290491 [ 3266 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:09.199790 [ 3298 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:09.293932 [ 3305 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:10.202654 [ 3315 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:10.297110 [ 3322 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:11.205510 [ 2822 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:11.301081 [ 3259 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:12.209196 [ 2852 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:12.304657 [ 2853 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:13.212598 [ 2863 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:13.310330 [ 2865 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:14.215588 [ 2871 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:14.313630 [ 2881 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:15.219637 [ 2894 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:15.317016 [ 2900 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:16.225519 [ 2913 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:16.319897 [ 2909 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:17.065010 [ 3896 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:17.228101 [ 2938 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:17.329384 [ 2934 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:18.230965 [ 2951 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:18.332974 [ 2954 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:19.235277 [ 2970 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:19.338575 [ 2972 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:20.238573 [ 2998 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:20.343294 [ 3000 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:21.241380 [ 3017 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:21.346999 [ 3022 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:22.245408 [ 3030 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:22.349407 [ 3045 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:23.323182 [ 3064 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:23.352056 [ 3063 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:24.326546 [ 3084 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:24.355464 [ 3077 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:25.329551 [ 3093 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:25.358485 [ 3102 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:26.331695 [ 3123 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:26.360862 [ 3118 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:27.334041 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:27.363403 [ 3143 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:28.336544 [ 3165 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:28.365902 [ 3168 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:29.339466 [ 3185 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:29.368348 [ 3189 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:30.342025 [ 3206 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:30.371488 [ 3195 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:31.344490 [ 3216 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:31.450601 [ 3220 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:32.348174 [ 3240 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:32.454318 [ 3244 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:33.351233 [ 3256 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:33.457039 [ 3258 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:34.354502 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:34.460492 [ 3279 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:35.357899 [ 3300 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:35.463739 [ 3309 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:36.360845 [ 3316 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:36.466602 [ 3332 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:37.364285 [ 2826 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:37.470089 [ 2824 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:38.374623 [ 2849 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:38.473366 [ 2855 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:39.377089 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:39.476302 [ 2873 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:40.380358 [ 2885 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:40.478911 [ 2878 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:41.192620 [ 3906 ] {e4812673-6548-439d-82af-3b9b5e1c7ea5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39484) (comment: 02378_analyzer_projection_names.sql) (in query: DROP DATABASE IF EXISTS test_pg9lc4qi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:25:41.195461 [ 3906 ] {e4812673-6548-439d-82af-3b9b5e1c7ea5} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:41.354318 [ 3896 ] {87d45264-fe16-45af-bb99-8de3796ac174} 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.10521.altinitytest (altinity build)) (from [::1]:51046) (comment: 02378_analyzer_projection_names.sql) (in query: DROP DATABASE IF EXISTS test_pg9lc4qi ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:25:41.364528 [ 3896 ] {87d45264-fe16-45af-bb99-8de3796ac174} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:41.382746 [ 2904 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:41.482076 [ 2898 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:42.385661 [ 2923 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:42.484521 [ 2927 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:43.388407 [ 2951 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:43.487717 [ 2948 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:44.391161 [ 2971 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:44.490398 [ 2969 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:44.858814 [ 4168 ] {4fe20525-609e-4a30-bf81-d6cc4d415fc3} executeQuery: Code: 403. DB::Exception: JOIN LEFT JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b) OR ((t1.d = t2.b) AND (t1.d = t2.b))) OR ((t1.e = t2.e) AND (t1.a = t2.a) AND (t2.f = t1.f)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58592) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 left join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b or t1.d = t2.b and t1.d = t2.b) or (t1.e = t2.e and t1.a=t2.a and t2.f=t1.f);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:455: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a5418 6. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:25:44.862927 [ 4168 ] {4fe20525-609e-4a30-bf81-d6cc4d415fc3} TCPHandler: Code: 403. DB::Exception: JOIN LEFT JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b) OR ((t1.d = t2.b) AND (t1.d = t2.b))) OR ((t1.e = t2.e) AND (t1.a = t2.a) AND (t2.f = t1.f)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:455: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a5418 6. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:25:44.942582 [ 4168 ] {304721c9-62e5-4c66-bd71-97cf19274c1c} executeQuery: Code: 403. DB::Exception: JOIN RIGHT JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b)) OR (t1.e = t2.e) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58592) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 right join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b) or t1.e = t2.e;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:455: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a5418 6. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:25:44.945755 [ 4168 ] {304721c9-62e5-4c66-bd71-97cf19274c1c} TCPHandler: Code: 403. DB::Exception: JOIN RIGHT JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b)) OR (t1.e = t2.e) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:455: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a5418 6. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:25:45.170493 [ 4168 ] {48f1c09a-65bd-456e-a7ee-56a602d46c6f} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b)) OR ((t1.e = t2.e) AND (t1.a = t2.a) AND (t2.f = t1.f)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58592) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 inner join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b) or (t1.e = t2.e and t1.a=t2.a and t2.f=t1.f);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:455: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a5418 6. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:25:45.183431 [ 4168 ] {48f1c09a-65bd-456e-a7ee-56a602d46c6f} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b)) OR ((t1.e = t2.e) AND (t1.a = t2.a) AND (t2.f = t1.f)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:455: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a5418 6. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 7. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 9. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 10. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 11. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:25:45.357594 [ 4168 ] {d3d39d31-2750-45f0-8b7a-1090b56c7085} executeQuery: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b)) AND ((t1.e = t2.e) OR (t1.f = t2.f)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58592) (comment: 01661_join_complex.sql) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 inner join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on (t1.d = t2.b or t1.c = t2.b) and (t1.e = t2.e or t1.f=t2.f);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:219: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ac998 6. ./build_docker/./src/Planner/PlannerJoins.cpp:472: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a3150 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:25:45.366611 [ 4168 ] {d3d39d31-2750-45f0-8b7a-1090b56c7085} TCPHandler: Code: 403. DB::Exception: JOIN INNER JOIN ... ON ((t1.d = t2.b) OR (t1.c = t2.b)) AND ((t1.e = t2.e) OR (t1.f = t2.f)) join expression contains column from left and right table, you may try experimental support of this feature by `SET allow_experimental_join_condition = 1`. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Planner/PlannerJoins.cpp:367: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ae078 5. ./build_docker/./src/Planner/PlannerJoins.cpp:219: DB::(anonymous namespace)::buildJoinClause(DB::ActionsDAG&, DB::ActionsDAG&, DB::ActionsDAG&, std::shared_ptr const&, std::shared_ptr const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&, DB::JoinNode const&, DB::JoinClause&) @ 0x00000000294ac998 6. ./build_docker/./src/Planner/PlannerJoins.cpp:472: DB::(anonymous namespace)::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, DB::JoinNode const&, std::shared_ptr const&) @ 0x00000000294a3150 7. ./build_docker/./src/Planner/PlannerJoins.cpp:660: DB::buildJoinClausesAndActions(std::vector> const&, std::vector> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000294a1c3f 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029477ced 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 12. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:25:45.393535 [ 2990 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:45.492572 [ 2998 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:46.396446 [ 3017 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:46.495878 [ 3015 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:47.399483 [ 3036 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:47.498250 [ 3031 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:48.402586 [ 3060 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:48.501316 [ 3049 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:49.405885 [ 3084 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:49.504578 [ 3074 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:50.409248 [ 3103 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:50.507599 [ 3109 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:51.004992 [ 3906 ] {86c39c29-885b-41f5-ae22-c70e6b9227cf} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42916) (comment: 00725_join_on_bug_4.sql) (in query: DROP DATABASE IF EXISTS test_ved9gjkc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:25:51.009740 [ 3906 ] {86c39c29-885b-41f5-ae22-c70e6b9227cf} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:51.105276 [ 5620 ] {824cc366-df68-4f13-aa59-0e85363c376f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42918) (comment: 00725_join_on_bug_4.sql) (in query: DROP DATABASE IF EXISTS test_ved9gjkc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:25:51.114365 [ 5620 ] {824cc366-df68-4f13-aa59-0e85363c376f} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:51.205101 [ 3906 ] {9a0cd5b5-f9c6-4426-ae87-253be0430a50} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42922) (comment: 00725_join_on_bug_4.sql) (in query: DROP DATABASE IF EXISTS test_ved9gjkc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:25:51.209385 [ 3906 ] {9a0cd5b5-f9c6-4426-ae87-253be0430a50} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:51.388883 [ 5620 ] {3e26535a-cb29-48b9-b987-7328b516531c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42928) (comment: 00725_join_on_bug_4.sql) (in query: DROP DATABASE IF EXISTS test_ved9gjkc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:25:51.402576 [ 5620 ] {3e26535a-cb29-48b9-b987-7328b516531c} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:51.411671 [ 3132 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:51.510848 [ 3138 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:51.513680 [ 4168 ] {ac52ff98-73ac-40ce-99ab-9b85a23c7d6b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42938) (comment: 00725_join_on_bug_4.sql) (in query: DROP DATABASE IF EXISTS test_ved9gjkc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:25:51.516884 [ 4168 ] {ac52ff98-73ac-40ce-99ab-9b85a23c7d6b} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:52.414594 [ 3150 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:52.513768 [ 3148 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:53.417505 [ 3166 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:53.516934 [ 3170 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:54.420507 [ 3200 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:54.519459 [ 3195 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:54.694987 [ 4168 ] {ae67a026-e395-426d-b6c1-a6c5bfc3a17f} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36384) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: INSERT INTO test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:25:54.715351 [ 4168 ] {ae67a026-e395-426d-b6c1-a6c5bfc3a17f} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:25:54.925123 [ 5620 ] {ecb4482e-be7d-4dac-b63f-5c8f1ca26418} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42958) (comment: 01346_alter_enum_partition_key_replicated_zookeeper_long.sql) (in query: DROP DATABASE IF EXISTS test_xixt5dk1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:25:54.930145 [ 5620 ] {ecb4482e-be7d-4dac-b63f-5c8f1ca26418} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:55.423251 [ 3231 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:55.522128 [ 3240 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:56.426340 [ 3250 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:56.529014 [ 3267 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:57.301251 [ 3906 ] {19e0bc41-025a-41b7-ab11-f9cb66d9de21} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54736) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[33]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.367113 [ 3906 ] {19e0bc41-025a-41b7-ab11-f9cb66d9de21} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(UInt8))): In scope SELECT formatRow('RawBLOB', [[[33]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.428510 [ 3284 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:57.466377 [ 3906 ] {dafa7e9c-53a3-41e5-8d23-350c6ec6f69e} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54736) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.470175 [ 3906 ] {dafa7e9c-53a3-41e5-8d23-350c6ec6f69e} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Nothing))): In scope SELECT formatRow('RawBLOB', [[[]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.516430 [ 3906 ] {638fc74a-dee5-41b0-95cc-505c02e44b33} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54736) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[[[[[[0x48, 0x65, 0x6c, 0x6c, 0x6f]]]]]], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.519978 [ 3906 ] {638fc74a-dee5-41b0-95cc-505c02e44b33} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(Array(Array(Array(Array(UInt8))))))): In scope SELECT formatRow('RawBLOB', [[[[[[[72, 101, 108, 108, 111]]]]]], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.531567 [ 3294 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:57.656088 [ 3906 ] {1029a26c-a13e-44c1-b883-ec1f7c4c4000} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54736) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', []::Array(Array(Nothing)));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.660835 [ 3906 ] {1029a26c-a13e-44c1-b883-ec1f7c4c4000} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Nothing)): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(Array(Nothing))')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.818823 [ 3906 ] {f60d2816-511f-4463-9567-7e5aabd4984d} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54736) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[], [['Hello']]]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.824467 [ 3906 ] {f60d2816-511f-4463-9567-7e5aabd4984d} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[], [['Hello']]]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.944580 [ 3906 ] {b2be74d7-aaef-4f2f-b217-d75388d102d1} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54736) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', [[['World']], []]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:57.949204 [ 3906 ] {b2be74d7-aaef-4f2f-b217-d75388d102d1} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Array(Array(String))): In scope SELECT formatRow('RawBLOB', [[['World']], []]). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:58.117787 [ 3906 ] {bdc8abc7-adf2-45da-b83e-af51546602b5} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54736) (comment: 02423_multidimensional_array_get_data_at.sql) (in query: SELECT formatRow('RawBLOB', []::Array(String));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:58.124661 [ 3906 ] {bdc8abc7-adf2-45da-b83e-af51546602b5} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(String): In scope SELECT formatRow('RawBLOB', CAST('[]', 'Array(String)')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Columns/ColumnArray.cpp:162: DB::ColumnArray::getDataAt(unsigned long) const @ 0x000000002ab2b6fd 5. ./build_docker/./src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:22: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x000000002d8d3e52 6. ./build_docker/./src/Processors/Formats/IRowOutputFormat.cpp:0: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x000000002d392582 7. DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fde599b 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:25:58.430729 [ 3322 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:58.534399 [ 3313 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:58.790712 [ 3316 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:59.433971 [ 2824 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:59.536986 [ 2835 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:59.546236 [ 2845 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:25:59.793491 [ 2827 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:00.439116 [ 4168 ] {2aaae26b-2da5-45cf-91e5-5527c7e1b1cc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44804) (comment: 02872_prewhere_filter.sql) (in query: DROP DATABASE IF EXISTS test_a8ffclir ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:26:00.445490 [ 4168 ] {2aaae26b-2da5-45cf-91e5-5527c7e1b1cc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:00.481981 [ 2844 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:00.539690 [ 2833 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:00.549039 [ 2867 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:00.574822 [ 2859 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:00.796253 [ 2868 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:01.484421 [ 2875 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:01.542652 [ 2888 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:01.551618 [ 2890 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:01.800755 [ 2891 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:02.487268 [ 2903 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:02.545979 [ 2897 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:02.555088 [ 2912 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:02.804076 [ 2915 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:03.490534 [ 2932 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:03.633234 [ 2933 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:03.634007 [ 2937 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:03.807367 [ 2939 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:04.494361 [ 2949 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:04.636668 [ 2957 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:04.637038 [ 2958 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:04.852891 [ 2965 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:05.497046 [ 2975 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:05.639899 [ 2994 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:05.640872 [ 2988 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:05.855655 [ 2991 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:06.499692 [ 3017 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:06.642383 [ 3010 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:06.643472 [ 3019 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:06.693160 [ 5620 ] {78b21855-fbb0-4257-92cb-1bbb19d41ab2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52168) (comment: 02373_analyzer_join_use_nulls.sql) (in query: DROP DATABASE IF EXISTS test_4zuov6l5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:26:06.708276 [ 5620 ] {78b21855-fbb0-4257-92cb-1bbb19d41ab2} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:06.828756 [ 4168 ] {3661b11f-c463-4632-a58b-1236b955a01d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52174) (comment: 02373_analyzer_join_use_nulls.sql) (in query: DROP DATABASE IF EXISTS test_4zuov6l5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:26:06.837767 [ 4168 ] {3661b11f-c463-4632-a58b-1236b955a01d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:06.858814 [ 3028 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:07.511782 [ 3040 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:07.644845 [ 3042 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:07.652581 [ 3044 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:07.861225 [ 3052 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:08.515571 [ 3056 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:08.648335 [ 3063 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:08.655911 [ 3065 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:08.864076 [ 3072 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:09.519547 [ 3088 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:09.655282 [ 3092 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:09.659235 [ 3086 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:09.867067 [ 3100 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:10.522598 [ 3103 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:10.661271 [ 3107 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:10.661708 [ 3108 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:10.870373 [ 3105 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:11.525464 [ 3135 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:11.664082 [ 3133 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:11.664642 [ 3138 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:11.873546 [ 3137 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:12.528133 [ 3162 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:12.666888 [ 3158 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:12.667411 [ 3159 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:12.876753 [ 3163 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:13.545414 [ 3184 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:13.669362 [ 3181 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:13.669943 [ 3190 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:13.887939 [ 3183 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:14.547880 [ 3196 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:14.672963 [ 3209 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:14.673377 [ 3218 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:14.890974 [ 3202 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:15.550808 [ 3225 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:15.677364 [ 3233 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:15.705036 [ 3235 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:15.901273 [ 3244 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:16.195618 [ 3248 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:16.556079 [ 3247 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:16.712736 [ 3256 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:16.775518 [ 3258 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:16.911328 [ 3265 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:17.123312 [ 3906 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:17.559292 [ 3275 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:17.715969 [ 3285 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:17.790702 [ 3278 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:17.913999 [ 3286 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:18.562178 [ 3297 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:18.718959 [ 3307 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:18.793533 [ 3311 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:18.917408 [ 3314 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:19.564609 [ 3334 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:19.721334 [ 2824 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:19.796190 [ 2845 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:19.920515 [ 2831 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:20.349314 [ 3437 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ed6da895-e75e-431a-aa82-98915ef53fc9::202510_1_51_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:20.570525 [ 2858 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:20.724069 [ 2864 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:20.798648 [ 2863 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:20.923537 [ 2841 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:21.573359 [ 2887 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:21.735229 [ 2884 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:21.801060 [ 2889 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:21.926705 [ 2894 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:22.078121 [ 2764 ] {64f51042-0b71-4079-9d6f-657432fc3a73} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41254) (comment: 00943_materialize_index.sh) (in query: SELECT count() FROM minmax_idx WHERE i64 = 2 SETTINGS merge_tree_read_split_ranges_into_intersecting_and_non_intersecting_injection_probability = 0.0 FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002defb871 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 22. ./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*) @ 0x000000002d37c7d7 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:26:22.103102 [ 2764 ] {64f51042-0b71-4079-9d6f-657432fc3a73} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002defb871 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 22. ./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*) @ 0x000000002d37c7d7 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:26:22.575778 [ 2917 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:22.742453 [ 2919 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:22.804146 [ 2932 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:22.931514 [ 2927 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:23.578637 [ 2951 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:23.745678 [ 2956 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:23.807334 [ 2958 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:23.934813 [ 2959 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:24.230116 [ 2962 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:24.582092 [ 2986 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:24.748566 [ 2987 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:24.810464 [ 2988 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:24.937908 [ 2990 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:25.586058 [ 3006 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:25.751701 [ 3009 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:25.819100 [ 3014 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:25.941252 [ 3017 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:26.588725 [ 3032 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:26.755917 [ 3020 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:26.821863 [ 3038 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:26.944321 [ 3041 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:27.132630 [ 3052 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:27.591457 [ 3069 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:27.759803 [ 3061 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:27.897542 [ 3076 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:27.947333 [ 3073 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:28.593598 [ 3104 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:28.763293 [ 3108 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:28.900125 [ 3105 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:28.950439 [ 3111 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:29.596352 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:29.767460 [ 3137 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:29.904438 [ 3141 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:29.952809 [ 3143 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:30.598906 [ 3157 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:30.772573 [ 3161 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:30.908415 [ 3166 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:30.955455 [ 3173 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:31.601076 [ 3192 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:31.774783 [ 3193 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:31.911914 [ 3191 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:31.958050 [ 3203 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:32.603618 [ 3223 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:32.777443 [ 3221 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:32.914916 [ 3227 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:32.960660 [ 3229 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:33.606582 [ 3237 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:33.780663 [ 3249 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:33.917577 [ 3253 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:33.964071 [ 3239 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:34.610141 [ 3268 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:34.783750 [ 3275 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:34.920603 [ 3276 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:34.969654 [ 3283 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:35.613241 [ 3296 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:35.826090 [ 3303 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:35.923564 [ 3288 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:35.972273 [ 3309 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:36.615623 [ 3331 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:36.828764 [ 2832 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:36.926643 [ 3334 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:36.976022 [ 2823 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:37.618046 [ 2837 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:37.831627 [ 2842 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:37.929713 [ 2848 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:37.979270 [ 2858 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:38.620553 [ 2868 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:38.834850 [ 2871 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:38.933034 [ 2880 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:38.986381 [ 2873 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:39.036296 [ 5620 ] {e16850e2-6fa6-4dc0-905d-3990ca5ed170} executeQuery: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34534) (comment: 01710_normal_projection_fix1.sql) (in query: CREATE TABLE t (`i` int, `j` int) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 39817, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 73, min_bytes_for_full_part_storage = 185844699, compact_parts_max_bytes_to_buffer = 464905563, compact_parts_max_granules_to_buffer = 244, compact_parts_merge_max_bytes_to_prefetch_part = 26008645, merge_max_block_size = 19212, old_parts_lifetime = 249., 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 = 28122243, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 94748, primary_key_compress_block_size = 73414), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:26:39.042843 [ 5620 ] {e16850e2-6fa6-4dc0-905d-3990ca5ed170} TCPHandler: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:26:39.622842 [ 2892 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:39.837760 [ 2906 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:39.935443 [ 2900 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:39.991571 [ 2895 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:40.625466 [ 2917 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:40.840319 [ 2928 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:40.938849 [ 2927 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:40.994879 [ 2938 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:41.627974 [ 2949 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:41.843051 [ 2952 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:41.886294 [ 2766 ] {44f9dcda-56f4-4dc8-91b8-1ffed7e13f4d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57664) (comment: 02788_fix_logical_error_in_sorting.sql) (in query: DROP DATABASE IF EXISTS test_17ucfojk ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:26:41.902284 [ 2766 ] {44f9dcda-56f4-4dc8-91b8-1ffed7e13f4d} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:41.942107 [ 2958 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:41.998039 [ 2964 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:42.061390 [ 2764 ] {ceb3888e-cbf8-4fca-8624-3fb78157364a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57676) (comment: 02788_fix_logical_error_in_sorting.sql) (in query: DROP DATABASE IF EXISTS test_17ucfojk ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:26:42.067207 [ 2764 ] {ceb3888e-cbf8-4fca-8624-3fb78157364a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:42.341552 [ 3906 ] {f1b3fbe5-a427-4e40-86b5-ae1b686c56ae} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57686) (comment: 02788_fix_logical_error_in_sorting.sql) (in query: DROP DATABASE IF EXISTS test_17ucfojk ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:26:42.344394 [ 3906 ] {f1b3fbe5-a427-4e40-86b5-ae1b686c56ae} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:42.630688 [ 2976 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:42.851252 [ 2977 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:42.945056 [ 2984 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:43.004873 [ 2985 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:43.404415 [ 3449 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3b7b9d5c-f30c-4cec-915e-651025b581f7::202510_1_70_14}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:43.633308 [ 2999 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:43.730832 [ 5620 ] {b55a4532-1d43-478c-929a-00338dff0a84} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34580) (comment: 03002_int_div_decimal_with_date_bug.sql) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:43.733031 [ 5620 ] {b55a4532-1d43-478c-929a-00338dff0a84} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), today()). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:43.853746 [ 3001 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:43.863578 [ 5620 ] {a5d2e238-27ca-4ec2-999e-af5e60d26448} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34580) (comment: 03002_int_div_decimal_with_date_bug.sql) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:43.883011 [ 5620 ] {a5d2e238-27ca-4ec2-999e-af5e60d26448} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 3) and Date of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(3)'), toDate('2023-01-02')). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:43.947890 [ 3008 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:44.013236 [ 3014 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:44.115186 [ 5620 ] {13a7c428-692b-406d-bb4a-5ecfdebb7a01} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and Date32 of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34580) (comment: 03002_int_div_decimal_with_date_bug.sql) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:44.117996 [ 5620 ] {13a7c428-692b-406d-bb4a-5ecfdebb7a01} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and Date32 of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDate32('2023-01-02 12:12:12')). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:44.203383 [ 5620 ] {ffe71f93-cc14-47c0-a0f1-968a9ac29f11} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34580) (comment: 03002_int_div_decimal_with_date_bug.sql) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:44.207189 [ 5620 ] {ffe71f93-cc14-47c0-a0f1-968a9ac29f11} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime('2023-01-02 12:12:12')). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:44.338601 [ 5620 ] {481639dc-25a0-41c9-8c06-88c366505cfe} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime64(3) of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34580) (comment: 03002_int_div_decimal_with_date_bug.sql) (in query: SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:44.374815 [ 5620 ] {481639dc-25a0-41c9-8c06-88c366505cfe} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(76, 2) and DateTime64(3) of arguments of function intDiv: In scope SELECT intDiv(CAST('1.0', 'Decimal256(2)'), toDateTime64('2023-01-02 12:12:12.002', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012856591 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000121df3c9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:26:44.638900 [ 3020 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:44.862933 [ 3027 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:44.950925 [ 3031 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:45.016039 [ 3045 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:45.641766 [ 3060 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:45.751637 [ 2764 ] {6c423b1a-e107-4544-a0c7-c374271e2e8e} 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.10521.altinitytest (altinity build)) (from [::1]:35606) (comment: 01846_alter_column_without_type_bugfix.sql) (in query: CREATE TABLE alter_test (a Int32, b DateTime) ENGINE = ReplacingMergeTree(b) ORDER BY a;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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>) @ 0x000000002cbb7308 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>&&) @ 0x000000002cbb5eda 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac598 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:26:45.763466 [ 2764 ] {6c423b1a-e107-4544-a0c7-c374271e2e8e} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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>) @ 0x000000002cbb7308 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>&&) @ 0x000000002cbb5eda 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac598 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:26:45.870266 [ 3055 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:45.953914 [ 3050 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:45.994616 [ 3906 ] {7a1ca437-a019-4ff9-9f39-c325d5fd5cba} executeQuery: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35610) (comment: 01710_projection_in_index.sql) (in query: CREATE TABLE t (`i` int, `j` int, `k` int, PROJECTION p (SELECT * ORDER BY j)) ENGINE = MergeTree ORDER BY i SETTINGS index_granularity = 1, min_bytes_for_wide_part = 305220601, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 89, min_bytes_for_full_part_storage = 170511705, compact_parts_max_bytes_to_buffer = 247028833, compact_parts_max_granules_to_buffer = 129, compact_parts_merge_max_bytes_to_prefetch_part = 3460624, merge_max_block_size = 2754, old_parts_lifetime = 196., prefer_fetch_merged_part_size_threshold = 9718281615, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 2514507974, index_granularity_bytes = 9591775, concurrent_part_removal_threshold = 70, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 31108, primary_key_compress_block_size = 63933), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:26:46.024238 [ 3064 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:46.024359 [ 3906 ] {7a1ca437-a019-4ff9-9f39-c325d5fd5cba} TCPHandler: Code: 57. DB::Exception: Table test_15.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:26:46.645163 [ 3073 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:46.873569 [ 3074 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:46.957933 [ 3080 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:47.027487 [ 3090 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:47.647670 [ 3093 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:47.877701 [ 3102 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:47.964424 [ 3104 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:48.030142 [ 3107 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:48.650822 [ 3128 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:48.880278 [ 3135 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:48.982371 [ 5620 ] {45baa40a-c569-4c6c-91f2-a00a05246bfe} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35630) (comment: 01049_zookeeper_synchronous_mutations_long.sql) (in query: INSERT INTO table_for_synchronous_mutations1 select number, number from numbers(100000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:26:48.991479 [ 5620 ] {45baa40a-c569-4c6c-91f2-a00a05246bfe} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:26:49.008150 [ 3140 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:49.032736 [ 3151 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:49.303343 [ 2764 ] {3086ea3f-a81f-4adf-b40d-e4ff0899b993} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48914) (comment: 01049_zookeeper_synchronous_mutations_long.sql) (in query: DROP DATABASE IF EXISTS test_6wd0bgcu ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:26:49.308206 [ 2764 ] {3086ea3f-a81f-4adf-b40d-e4ff0899b993} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:49.653767 [ 3163 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:49.883221 [ 3167 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:50.011678 [ 3170 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:50.035324 [ 3173 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:50.739061 [ 3183 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:50.887080 [ 3192 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:51.013994 [ 3201 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:51.046032 [ 3193 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:51.742731 [ 3210 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:51.889500 [ 3214 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:52.016060 [ 3229 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:52.049386 [ 3230 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:52.350899 [ 4168 ] {d31b8852-0669-400e-8066-5db60017d7f9} executeQuery: Code: 57. DB::Exception: Table test_15.tab_00650 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35684) (comment: 00650_array_enumerate_uniq_with_tuples.sql) (in query: create table tab_00650 (val UInt32, n Nested(x Nullable(UInt8), y 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:26:52.356703 [ 4168 ] {d31b8852-0669-400e-8066-5db60017d7f9} TCPHandler: Code: 57. DB::Exception: Table test_15.tab_00650 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:26:52.745528 [ 3249 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:52.892007 [ 3251 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:53.018902 [ 3256 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:53.037113 [ 3258 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:53.060100 [ 3263 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:53.748479 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:53.892874 [ 3291 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:53.894594 [ 3284 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:54.021383 [ 3304 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:54.039229 [ 3297 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:54.062642 [ 3305 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:54.751948 [ 3319 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:54.897336 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:54.898103 [ 3315 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:55.024014 [ 3334 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:55.042821 [ 2839 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:55.064930 [ 2826 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:55.755201 [ 2837 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:55.900428 [ 2834 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:55.901307 [ 2838 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:56.026596 [ 2846 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:56.052418 [ 2836 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:56.067230 [ 2844 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:56.758712 [ 2874 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:56.903857 [ 2878 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:56.904573 [ 2886 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:57.032298 [ 2888 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:57.058113 [ 2890 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:57.069552 [ 2896 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:57.761555 [ 2915 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:57.906883 [ 2921 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:57.907858 [ 2920 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:58.034663 [ 2924 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:58.060255 [ 2930 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:58.071642 [ 2913 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:58.764495 [ 2955 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:58.909493 [ 2965 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:58.918776 [ 2965 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:59.037280 [ 2961 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:59.062685 [ 2962 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:59.074000 [ 2968 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:59.768003 [ 2996 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:59.912857 [ 2999 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:26:59.923367 [ 2995 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:00.039971 [ 3006 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:00.066792 [ 3008 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:00.078804 [ 3014 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:00.770565 [ 3038 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:00.915996 [ 3039 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:00.926587 [ 3051 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:01.042531 [ 3041 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:01.068976 [ 3060 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:01.082466 [ 3059 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:01.591162 [ 3906 ] {0466445e-a83f-48f5-8b42-9709e418f0bd} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 31.05 MiB (attempt to allocate chunk of 1112477 bytes), maximum: 30.00 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35698) (comment: 02228_merge_tree_insert_memory_usage.sql) (in query: insert into data_02228 select number, 1, number from numbers_mt(10_000) settings max_memory_usage='30Mi', max_partitions_per_insert_block=1024, max_insert_delayed_streams_for_parallel_write=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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>&&) @ 0x000000001adfe6bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfce3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad30b85 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000001aeaca60 9. ./src/IO/BufferWithOwnMemory.h:0: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001af041a2 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000001af02171 11. ./build_docker/./src/IO/WriteBufferFromFile.cpp:36: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000001b1352d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x00000000280395b7 13. ./build_docker/./src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000028027f33 14. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:0: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c26d77a 15. ./src/Storages/MergeTree/IDataPartStorage.h:0: DB::MergeTreePartition::store(DB::Block const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&, DB::WriteSettings const&) const @ 0x000000002c78c94c 16. ./build_docker/./src/Storages/MergeTree/MergeTreePartition.cpp:0: DB::MergeTreePartition::store(std::shared_ptr, std::shared_ptr, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x000000002c78c398 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:267: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8ec033 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000002cc34a69 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 23. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 30. ./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*) @ 0x000000002d356ec7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 2025.10.15 20:27:01.595713 [ 3906 ] {0466445e-a83f-48f5-8b42-9709e418f0bd} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 31.05 MiB (attempt to allocate chunk of 1112477 bytes), maximum: 30.00 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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>&&) @ 0x000000001adfe6bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfce3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfc7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3489d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad30b85 8. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000001aeaca60 9. ./src/IO/BufferWithOwnMemory.h:0: DB::WriteBufferFromFileBase::WriteBufferFromFileBase(unsigned long, char*, unsigned long) @ 0x000000001af041a2 10. ./build_docker/./src/IO/WriteBufferFromFileDescriptor.cpp:102: DB::WriteBufferFromFileDescriptor::WriteBufferFromFileDescriptor(int, unsigned long, char*, std::shared_ptr, unsigned long, String) @ 0x000000001af02171 11. ./build_docker/./src/IO/WriteBufferFromFile.cpp:36: DB::WriteBufferFromFile::WriteBufferFromFile(String const&, unsigned long, int, std::shared_ptr, unsigned int, char*, unsigned long) @ 0x000000001b1352d2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007] const&>(std::__fs::filesystem::path&&, unsigned long&, int&, std::shared_ptr const&) @ 0x00000000280395b7 13. ./build_docker/./src/Disks/DiskLocal.cpp:341: DB::DiskLocal::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x0000000028027f33 14. ./build_docker/./src/Storages/MergeTree/DataPartStorageOnDiskFull.cpp:0: DB::DataPartStorageOnDiskFull::writeFile(String const&, unsigned long, DB::WriteMode, DB::WriteSettings const&) @ 0x000000002c26d77a 15. ./src/Storages/MergeTree/IDataPartStorage.h:0: DB::MergeTreePartition::store(DB::Block const&, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&, DB::WriteSettings const&) const @ 0x000000002c78c94c 16. ./build_docker/./src/Storages/MergeTree/MergeTreePartition.cpp:0: DB::MergeTreePartition::store(std::shared_ptr, std::shared_ptr, DB::IDataPartStorage&, DB::MergeTreeDataPartChecksums&) const @ 0x000000002c78c398 17. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:267: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8ec033 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 20. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSink.cpp:0: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000002cc34a69 22. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 23. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 24. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 30. ./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*) @ 0x000000002d356ec7 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 2025.10.15 20:27:01.773158 [ 3080 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:01.779688 [ 5061 ] {} test_6w353n2h.data_02228 (3f2d1a4a-6879-4d9a-b22e-be25939779f8): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.15 20:27:01.814083 [ 5061 ] {} DatabaseCatalog: Cannot drop table test_6w353n2h.data_02228 (3f2d1a4a-6879-4d9a-b22e-be25939779f8). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c4864e5 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>*) @ 0x000000002c48482e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c490379 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286cb897 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286dd364 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a6025 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:01.918880 [ 3075 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:01.929256 [ 3077 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:02.049762 [ 3087 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:02.071868 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:02.085453 [ 3086 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:02.776514 [ 3110 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:02.922511 [ 3111 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:02.932350 [ 3116 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:03.053012 [ 3113 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:03.074998 [ 3117 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:03.088317 [ 3120 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:03.779615 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:03.925797 [ 3143 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:03.937864 [ 3149 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:04.055940 [ 3151 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:04.077929 [ 3153 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:04.091404 [ 3160 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:04.781969 [ 3170 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:04.957838 [ 3177 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:05.033113 [ 3184 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:05.087403 [ 3175 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:05.094296 [ 3176 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:05.136553 [ 3180 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:05.784604 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:05.960720 [ 3202 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:06.037732 [ 3208 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:06.090190 [ 3215 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:06.097124 [ 3210 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:06.142328 [ 3223 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:06.787257 [ 3241 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:06.963822 [ 3237 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:07.040695 [ 3246 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:07.092912 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:07.099983 [ 3251 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:07.145093 [ 3239 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:07.790071 [ 3287 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:07.812177 [ 3906 ] {5a0834c0-5f73-41a8-964a-2fcba6767366} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35698) (comment: 02228_merge_tree_insert_memory_usage.sql) (in query: insert into data_rep_02228 select number, 1, number from numbers_mt(10_000) settings max_memory_usage='30Mi', max_partitions_per_insert_block=1024, max_insert_delayed_streams_for_parallel_write=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:27:07.815172 [ 3906 ] {5a0834c0-5f73-41a8-964a-2fcba6767366} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:27:07.879911 [ 4168 ] {217baed7-9d83-4b0a-999a-c6b4c3de6525} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=7): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37896) (comment: 02801_backup_native_copy.sh) (in query: SELECT query, ProfileEvents['S3CopyObject']>0 FROM system.query_log WHERE type = 'QueryFinish' AND event_date >= yesterday() AND current_database = 'test_15' AND query_id = 'vxaqqescnz' ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:27:07.904247 [ 4168 ] {217baed7-9d83-4b0a-999a-c6b4c3de6525} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=7): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:27:07.966440 [ 3283 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:08.043286 [ 3284 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:08.064454 [ 2766 ] {12970516-b8b9-4545-9cec-4754169f8c49} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34104) (comment: 02228_merge_tree_insert_memory_usage.sql) (in query: DROP DATABASE IF EXISTS test_6w353n2h ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:27:08.067635 [ 2766 ] {12970516-b8b9-4545-9cec-4754169f8c49} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:08.095443 [ 3294 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:08.103035 [ 3282 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:08.147426 [ 3296 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:08.793484 [ 3312 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:08.969308 [ 3320 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:09.046313 [ 3317 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:09.100291 [ 3324 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:09.106679 [ 3319 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:09.195395 [ 3310 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:09.797380 [ 2826 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:09.971941 [ 2828 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:10.049127 [ 2845 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:10.111770 [ 3335 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:10.111881 [ 2831 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:10.202153 [ 2827 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:10.799718 [ 2833 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:10.974446 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:11.051341 [ 2864 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:11.113986 [ 2865 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:11.114372 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:11.217640 [ 2858 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:11.802731 [ 2870 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:11.977066 [ 2883 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:12.053667 [ 2890 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:12.116296 [ 2894 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:12.116923 [ 2884 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:12.220390 [ 2902 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:12.740835 [ 2903 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:12.805377 [ 2905 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:12.979866 [ 2914 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:13.068751 [ 2916 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:13.119215 [ 2921 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:13.120303 [ 2918 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:13.222904 [ 2913 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:13.743365 [ 2945 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:13.812282 [ 2948 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:13.982622 [ 2949 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:14.071449 [ 2956 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:14.121993 [ 2958 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:14.123489 [ 2964 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:14.226150 [ 2966 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:14.746677 [ 2985 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:14.815173 [ 2980 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:14.985700 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.074470 [ 2998 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.124944 [ 2996 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.128364 [ 2992 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.229554 [ 3003 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.279932 [ 3439 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {85a939ff-1bdc-434a-abe3-c1f1ded4b10d::202510_1_95_19}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.583877 [ 2764 ] {e9220dfb-37f7-41dc-a2d0-2f838045a0b3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37938) (comment: 01824_prefer_global_in_and_join.sql) (in query: DROP DATABASE test_01824;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:27:15.590675 [ 2764 ] {e9220dfb-37f7-41dc-a2d0-2f838045a0b3} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:27:15.750084 [ 3013 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.817452 [ 3015 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:15.988359 [ 3012 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:16.077079 [ 3010 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:16.127696 [ 3024 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:16.130778 [ 3019 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:16.232483 [ 3032 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:16.752691 [ 3044 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:16.819951 [ 3047 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:16.991222 [ 3041 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:17.079586 [ 3043 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:17.129810 [ 3052 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:17.133490 [ 3042 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:17.234935 [ 3055 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:17.277834 [ 2766 ] {6b762635-23f8-44e2-9b2a-92c40edc746e} executeQuery: Code: 57. DB::Exception: Table test_15.date_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54902) (comment: 01018_ddl_dictionaries_special.sql) (in query: CREATE TABLE test_15.date_table (`CountryID` UInt64, `StartDate` Date, `EndDate` Date, `Tax` Float64) ENGINE = MergeTree ORDER BY CountryID SETTINGS index_granularity = 52153, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 107590308, compact_parts_max_bytes_to_buffer = 25799281, compact_parts_max_granules_to_buffer = 50, compact_parts_merge_max_bytes_to_prefetch_part = 15767365, merge_max_block_size = 22711, old_parts_lifetime = 90., prefer_fetch_merged_part_size_threshold = 316493228, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 819367746, index_granularity_bytes = 29717630, concurrent_part_removal_threshold = 74, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 81539, primary_key_compress_block_size = 82867), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:27:17.291469 [ 2766 ] {6b762635-23f8-44e2-9b2a-92c40edc746e} TCPHandler: Code: 57. DB::Exception: Table test_15.date_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:27:17.755839 [ 3085 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:17.815907 [ 4168 ] {fa531699-20c2-4920-8a40-b0a73703c7fb} executeQuery: Code: 57. DB::Exception: Table test_01824.t2_distr already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54894) (comment: 01824_prefer_global_in_and_join.sql) (in query: create table t2_distr as t2_shard engine Distributed(test_cluster_two_shards_localhost, test_01824, t2_shard, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:27:17.829923 [ 3072 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:17.835150 [ 4168 ] {fa531699-20c2-4920-8a40-b0a73703c7fb} TCPHandler: Code: 57. DB::Exception: Table test_01824.t2_distr already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:27:17.993619 [ 3067 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:18.082546 [ 3090 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:18.176427 [ 3075 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:18.176842 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:18.237790 [ 3088 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:18.758726 [ 3106 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:18.839546 [ 3115 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:18.972507 [ 4168 ] {bdc3b4c5-8463-4b69-8057-484ecc61c1a4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54928) (comment: 01825_type_json_ephemeral.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:27:18.987059 [ 4168 ] {bdc3b4c5-8463-4b69-8057-484ecc61c1a4} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:27:19.001050 [ 3112 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.085360 [ 3111 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.179654 [ 3105 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.180110 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.241070 [ 3097 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.678166 [ 2764 ] {44c2ab17-34c0-4e69-b832-843023937259} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ('1'): 1. Max query size exceeded: '1'. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50040) (comment: 00612_h) (in query: select ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:27:19.685449 [ 2764 ] {44c2ab17-34c0-4e69-b832-843023937259} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ('1'): 1. Max query size exceeded: '1'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.761946 [ 3130 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.842711 [ 3132 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:19.921181 [ 2766 ] {cb4de6b4-796c-457e-a0ea-a30078ca9000} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 (''11''): '11'. Max query size exceeded: ''11''. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50062) (comment: 00612_http) (in query: select '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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:27:19.923964 [ 2766 ] {cb4de6b4-796c-457e-a0ea-a30078ca9000} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 (''11''): '11'. Max query size exceeded: ''11''. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:20.004527 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:20.087780 [ 3141 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:20.182399 [ 3140 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:20.193434 [ 3148 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:20.244674 [ 3151 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:20.764979 [ 3159 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:20.845314 [ 3161 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.012204 [ 3167 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.090932 [ 3146 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.184843 [ 3184 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.195915 [ 3182 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.247196 [ 3190 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.505147 [ 4168 ] {e1e55c38-249b-4f98-b02d-f9b74ecce8ee} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 2097152 (' ') (line 2047, col 1024): . Max query size exceeded: ' '. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49458) (comment: 00612_http_max_query_size.sh) (in query: select sum(number) from (select * from system.numbers limit 10000000) where number = 0 or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000001' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000002' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000003' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000004' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000005' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000006' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000007' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000008' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000009' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000010' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000011' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000012' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000013' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000014' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000015' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000016' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000017' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000018' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000019' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000020' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000021' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000022' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000023' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000024' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000025' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000026' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000027' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000028' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000029' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000030' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000031' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000032' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000033' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000034' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000035' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000036' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000037' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000038' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000039' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000040' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000041' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000042' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000043' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000044' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000045' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000046' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000047' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000048' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000049' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000050' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000051' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000052' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000053' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000054' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000055' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000056' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000057' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000058' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000059' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000060' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000061' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000062' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000063' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000064' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000065' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000066' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000067' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000068' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000069' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000070' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000071' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000072' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000073' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000074' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000075' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000076' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000077' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000078' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000079' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000080' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000081' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000082' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000083' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000084' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000085' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000086' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000087' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000088' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000089' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000090' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000091' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000092' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000093' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000094' or toString(number) = '00000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000095' or toString(number) = '000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000000... (truncated 1997200 characters)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:27:21.514198 [ 4168 ] {e1e55c38-249b-4f98-b02d-f9b74ecce8ee} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 2097152 (' ') (line 2047, col 1024): . Max query size exceeded: ' '. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.767982 [ 3197 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:21.848308 [ 3201 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:22.014640 [ 3195 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:22.093245 [ 3196 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:22.187205 [ 3209 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:22.198591 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:22.249268 [ 3199 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:22.770752 [ 3230 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:22.850932 [ 3228 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.017279 [ 3233 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.095553 [ 3249 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.145359 [ 4168 ] {72fc69f7-8d83-4f4f-8ec6-9bcf875e1529} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54992) (comment: 02863_delayed_source_with_totals_and_extremes.sql) (in query: INSERT INTO 02863_delayed_source 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:27:23.162689 [ 4168 ] {72fc69f7-8d83-4f4f-8ec6-9bcf875e1529} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:751: DB::InterpreterInsertQuery::execute() @ 0x000000002936162d 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:27:23.190269 [ 3257 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.200843 [ 3243 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.251361 [ 3253 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.402637 [ 2766 ] {8784fadf-a145-4b1a-bc33-f24a0696d7d4} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49470) (comment: 02863_delayed_source_with_totals_and_extremes.sql) (in query: DROP DATABASE IF EXISTS test_pgfcbq30 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:27:23.407800 [ 2766 ] {8784fadf-a145-4b1a-bc33-f24a0696d7d4} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba)) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002918d83e 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f55a1 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>>>&) @ 0x00000000291fb9cc 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.807114 [ 3250 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:23.853750 [ 3274 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:24.019860 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:24.098016 [ 3277 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:24.192391 [ 3261 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:24.203854 [ 3287 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:24.253934 [ 3283 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:24.351292 [ 2764 ] {b71cc7b6-be34-47aa-8904-04292285c5cd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54982) (comment: 00926_adaptive_index_granularity_pk.sql) (in query: SELECT toUInt32(x), y, z FROM pk WHERE (x BETWEEN toDateTime(60) AND toDateTime(120)) AND y = 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:27:24.358135 [ 2764 ] {b71cc7b6-be34-47aa-8904-04292285c5cd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:27:24.810392 [ 3298 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:24.857232 [ 3304 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:25.025320 [ 3299 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:25.100695 [ 3306 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:25.195311 [ 3300 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:25.206906 [ 3311 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:25.261269 [ 3312 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:25.438627 [ 2764 ] {4d27d05e-4f0a-47c9-afe0-a17a49f88c99} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40024) (comment: 02876_s3_cluster_schema_inference_names_with_spaces.sql) (in query: SELECT __table1.`a b c` AS `a b c` FROM s3Cluster(test_cluster_one_shard_three_replicas_localhost, 'http://localhost:11111/test/02876.parquet', 'Parquet', '`a b c` Nullable(UInt8)') 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:27:25.444013 [ 2764 ] {4d27d05e-4f0a-47c9-afe0-a17a49f88c99} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:27:25.464332 [ 5620 ] {2ed8ca85-a547-4e92-8cba-9cde0d17c9d2} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=733). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55014) (comment: 02876_s3_cluster_schema_inference_names_with_spaces.sql) (in query: select * from s3Cluster(test_cluster_one_shard_three_replicas_localhost, 'http://localhost:11111/test/02876.parquet');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf9eb9e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b0f96 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:27:25.470495 [ 5620 ] {2ed8ca85-a547-4e92-8cba-9cde0d17c9d2} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.3:9000. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=733). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 : 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cf9eb9e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b0f96 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:27:25.813957 [ 3329 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:25.859893 [ 2822 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:26.028014 [ 2826 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:26.114842 [ 3325 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:26.198197 [ 2851 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:26.209885 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:26.264384 [ 2850 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:26.817213 [ 2848 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:26.862251 [ 2844 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.030316 [ 2857 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.118942 [ 2869 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.240693 [ 5620 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.252040 [ 2858 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.252551 [ 2829 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.267583 [ 2877 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.820332 [ 2878 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:27.865197 [ 2875 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.034228 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.089296 [ 2884 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.121493 [ 2902 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.255169 [ 2904 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.256120 [ 2900 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.270486 [ 2907 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.822522 [ 2915 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:28.867759 [ 2919 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.036739 [ 2937 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.091434 [ 2934 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.124100 [ 2939 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.211547 [ 5620 ] {6e07a242-197b-43ed-8d25-b4d65c8c1d20} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40578) (comment: 03290_final_replacing.sql) (in query: DROP DATABASE IF EXISTS test_8ecpbov1 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:27:29.215271 [ 5620 ] {6e07a242-197b-43ed-8d25-b4d65c8c1d20} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.258108 [ 2940 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.258608 [ 2947 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.273095 [ 2946 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.826544 [ 2958 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:29.870867 [ 2953 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.045645 [ 2973 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.093993 [ 2968 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.126909 [ 2972 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.260612 [ 2969 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.261294 [ 2963 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.338739 [ 2984 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.371397 [ 5068 ] {ae54732c-b330-41f0-bdcd-9d6c36f67852} ExternalDictionariesLoader: Could not load external dictionary '5354808d-cb1c-44fe-8d21-43f348be1c48', next update is scheduled at 2025-10-15 20:27:35: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.382790 [ 2764 ] {ae54732c-b330-41f0-bdcd-9d6c36f67852} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): while executing 'FUNCTION dictGet('01760_db.dict_array'_String : 2, 'name'_String :: 3, tuple(__table1.x, __table1.y) : 6) -> dictGet('01760_db.dict_array'_String, 'name'_String, tuple(__table1.x, __table1.y)) String : 1'. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53284) (comment: 01760_polygon_dictionaries.sql) (in query: SELECT tuple(x, y) as key, dictGet('01760_db.dict_array', 'name', key), dictGet('01760_db.dict_array', 'value', key), dictGet('01760_db.dict_array', 'value_nullable', key) FROM 01760_db.points ORDER BY x, y;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:27:30.385005 [ 2764 ] {ae54732c-b330-41f0-bdcd-9d6c36f67852} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0): while executing 'FUNCTION dictGet('01760_db.dict_array'_String : 2, 'name'_String :: 3, tuple(__table1.x, __table1.y) : 6) -> dictGet('01760_db.dict_array'_String, 'name'_String, tuple(__table1.x, __table1.y)) String : 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:27:30.829320 [ 2991 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:30.873697 [ 2979 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.048276 [ 2995 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.096740 [ 2997 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.129290 [ 2990 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.264134 [ 3009 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.264841 [ 3011 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.341168 [ 3018 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.833045 [ 3033 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:31.876747 [ 3035 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.050450 [ 3038 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.099155 [ 3044 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.132107 [ 3030 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.267399 [ 3051 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.268007 [ 3053 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.344434 [ 3048 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.835467 [ 3042 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:32.880989 [ 3050 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.053829 [ 3060 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.101911 [ 3062 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.134399 [ 3069 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.270264 [ 3056 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.270426 [ 3068 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.353303 [ 3072 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.839048 [ 3075 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:33.886126 [ 3077 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.056933 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.104941 [ 3082 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.136805 [ 3094 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.272525 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.273171 [ 3104 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.356499 [ 3107 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.844755 [ 3117 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:34.896487 [ 3120 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.059675 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.107589 [ 3124 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.139692 [ 3128 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.274976 [ 3129 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.275410 [ 3121 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.359594 [ 3130 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.824682 [ 2764 ] {6adb0d3b-1d1a-4ee7-b5d6-2591d5b65ebd} 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.10521.altinitytest (altinity build)) (from [::1]:57158) (comment: 00597_with_totals_on_empty_set.sql) (in query: SELECT number, count() FROM numbers(10) WHERE number = -1 GROUP BY number WITH TOTALS FORMAT Vertical;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:27:35.830046 [ 2764 ] {6adb0d3b-1d1a-4ee7-b5d6-2591d5b65ebd} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:27:35.847385 [ 3141 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:35.899452 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.062139 [ 3149 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.110265 [ 3152 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.142805 [ 3153 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.277351 [ 3158 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.277657 [ 3162 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.362136 [ 3155 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.850473 [ 3184 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:36.902712 [ 3181 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.065282 [ 3179 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.112969 [ 3183 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.145609 [ 3185 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.279643 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.280203 [ 3197 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.364956 [ 3193 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.854720 [ 3199 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:37.906140 [ 3208 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.069312 [ 3220 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.115726 [ 3222 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.247335 [ 3238 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.281949 [ 3235 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.282516 [ 3231 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.444912 [ 3240 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.857800 [ 3225 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:38.909547 [ 3244 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.071867 [ 3243 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.124381 [ 3253 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.250159 [ 3254 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.284677 [ 3260 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.285632 [ 3263 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.448341 [ 3262 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.860982 [ 3279 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:39.912666 [ 3261 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.074506 [ 3284 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.127709 [ 3289 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.253467 [ 3266 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.288767 [ 3296 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.289159 [ 3301 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.451164 [ 3304 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.864319 [ 3308 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:40.915924 [ 3312 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.076861 [ 3320 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.191750 [ 3317 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.256131 [ 3319 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.291699 [ 3328 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.293417 [ 3310 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.454001 [ 3315 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.867370 [ 2823 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:41.919533 [ 2828 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.081845 [ 2845 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.194567 [ 2850 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.261015 [ 2830 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.294617 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.295886 [ 2824 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.456924 [ 2838 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.870147 [ 2853 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:42.923016 [ 2860 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.084386 [ 2867 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.203391 [ 2869 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.264284 [ 2843 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.297410 [ 2858 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.303103 [ 2829 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.459466 [ 2873 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.873186 [ 2861 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:43.925655 [ 2878 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.164679 [ 2890 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.205955 [ 2891 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.267043 [ 2899 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.299856 [ 2900 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.305158 [ 2907 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.462052 [ 2897 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.876462 [ 2920 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:44.928774 [ 2921 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.167178 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.207886 [ 2928 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.269420 [ 2938 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.302297 [ 2936 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.311362 [ 2935 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.464545 [ 2917 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.879352 [ 2933 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:45.931857 [ 2942 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.170726 [ 2956 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.210470 [ 2958 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.272315 [ 2965 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.312623 [ 2973 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.313765 [ 2960 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.467273 [ 2961 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.882745 [ 2984 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:46.935358 [ 2978 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.173768 [ 2988 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.213536 [ 2987 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.275047 [ 2982 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.315763 [ 2983 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.316635 [ 2986 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.513347 [ 2998 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.885784 [ 3006 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:47.938190 [ 3001 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.176278 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.216214 [ 3000 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.279710 [ 3028 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.319607 [ 3025 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.320252 [ 3024 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.516169 [ 3016 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.896728 [ 3037 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:48.940669 [ 3031 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.179314 [ 3044 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.219487 [ 3027 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.283251 [ 3039 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.322338 [ 3051 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.390377 [ 3053 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.520319 [ 3049 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.899421 [ 3071 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:49.994564 [ 3065 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.185819 [ 3076 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.221802 [ 3072 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.287287 [ 3073 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.324962 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.393041 [ 3067 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.522951 [ 3075 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.901879 [ 3087 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:50.996998 [ 3092 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.188837 [ 3091 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.224628 [ 3093 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.289945 [ 3101 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.327365 [ 3099 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.395327 [ 3104 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.525946 [ 3109 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.825238 [ 3436 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {24310d89-f4f4-4694-b8de-dac7140488d3::202510_1_89_54}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.904745 [ 3117 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:51.999556 [ 3114 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:52.191715 [ 3118 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:52.227685 [ 3129 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:52.292886 [ 3121 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:52.330390 [ 3135 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:52.430335 [ 3132 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:52.528744 [ 3125 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:52.916953 [ 3140 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.004462 [ 3153 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.194372 [ 3147 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.231527 [ 3164 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.295816 [ 3157 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.333632 [ 3155 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.432866 [ 3161 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.531378 [ 3167 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:53.920511 [ 3163 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.006849 [ 3190 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.224636 [ 3178 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.234595 [ 3188 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.298246 [ 3185 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.336301 [ 3187 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.436611 [ 3175 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.535488 [ 3191 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:54.923527 [ 3196 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.009451 [ 3209 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.227127 [ 3208 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.237016 [ 3215 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.300537 [ 3210 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.339035 [ 3223 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.439647 [ 3220 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.538329 [ 3217 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:55.926196 [ 3235 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.020888 [ 3240 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.229238 [ 3227 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.239515 [ 3232 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.303142 [ 3249 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.342153 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.442975 [ 3225 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.541208 [ 3257 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:56.929298 [ 3254 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.023464 [ 3267 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.231600 [ 3271 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.242583 [ 3274 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.306032 [ 3272 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.345117 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.446647 [ 3280 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.543739 [ 3279 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:57.932665 [ 3275 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.026475 [ 3284 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.233725 [ 3291 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.244962 [ 3282 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.309954 [ 3301 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.347457 [ 3298 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.449385 [ 3304 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.546194 [ 3297 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:58.935963 [ 3295 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.029753 [ 3300 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.238023 [ 3314 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.255435 [ 3322 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.312681 [ 3320 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.353449 [ 3302 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.454443 [ 3326 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.548927 [ 3310 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:27:59.938645 [ 3334 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.032507 [ 2828 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.241691 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.258082 [ 2850 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.315542 [ 2847 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.356468 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.457012 [ 2824 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.551280 [ 2831 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:00.940985 [ 2848 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.035062 [ 2846 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.245047 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.260866 [ 2865 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.318017 [ 2859 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.358678 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.459621 [ 2829 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.553713 [ 2876 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:01.943768 [ 2880 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.037608 [ 2881 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.247724 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.264021 [ 2888 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.320668 [ 2889 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.361414 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.462508 [ 2901 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.556776 [ 2886 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:02.946724 [ 2907 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.044869 [ 2905 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.250512 [ 2897 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.266485 [ 2912 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.324006 [ 2910 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.366363 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.465301 [ 2921 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.559271 [ 2930 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:03.949770 [ 2928 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.047708 [ 2934 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.253209 [ 2917 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.270581 [ 2926 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.327451 [ 2940 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.369049 [ 2946 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.473186 [ 2922 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.562334 [ 2933 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:04.952371 [ 2949 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.051314 [ 2958 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.255830 [ 2966 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.273267 [ 2950 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.330386 [ 2973 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.371807 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.476854 [ 2972 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.565761 [ 2961 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:05.955122 [ 2963 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.056560 [ 2978 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.268127 [ 2988 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.276912 [ 2987 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.335485 [ 2983 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.377959 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.479890 [ 2996 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.568729 [ 2998 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:06.957789 [ 3005 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.059044 [ 3011 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.270951 [ 3000 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.280017 [ 3022 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.338441 [ 3012 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.418201 [ 3024 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.532764 [ 3019 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.571371 [ 3029 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:07.960485 [ 3037 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.061095 [ 3031 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.273831 [ 3027 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.282871 [ 3039 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.342404 [ 3048 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.420819 [ 3057 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.536137 [ 3053 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.579366 [ 3059 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:08.963822 [ 3060 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.063971 [ 3063 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.276783 [ 3065 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.285904 [ 3058 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.344560 [ 3081 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.423588 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.539248 [ 3067 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.582474 [ 3090 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:09.970182 [ 3087 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.066167 [ 3094 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.280273 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.288936 [ 3096 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.347733 [ 3088 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.426435 [ 3099 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.541948 [ 3103 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.585499 [ 3109 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:10.972490 [ 3110 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.068720 [ 3117 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.283372 [ 3124 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.291659 [ 3122 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.351157 [ 3126 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.430080 [ 3118 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.545594 [ 3129 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.588980 [ 3121 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:11.975126 [ 3123 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.071734 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.286325 [ 3149 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.294608 [ 3148 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.354425 [ 3151 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.433647 [ 3160 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.548836 [ 3139 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.592498 [ 3156 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:12.978520 [ 3159 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.074829 [ 3154 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.297376 [ 3170 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.289072 [ 3146 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.357927 [ 3168 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.436808 [ 3177 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.556271 [ 3171 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.595197 [ 3163 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:13.982434 [ 3182 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.077828 [ 3180 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.299867 [ 3192 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.301297 [ 3185 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.360516 [ 3186 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.439312 [ 3197 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.560730 [ 3193 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.597986 [ 3203 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:14.985217 [ 3209 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.081198 [ 3205 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.303768 [ 3202 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.309681 [ 3208 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.373995 [ 3215 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.442819 [ 3223 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.563613 [ 3230 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.600528 [ 3222 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:15.988068 [ 3237 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:16.084305 [ 3214 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:16.306842 [ 3246 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:16.312314 [ 3249 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:16.383924 [ 3225 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:16.445613 [ 3244 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:16.566856 [ 3257 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:16.603539 [ 3234 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.002770 [ 3263 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.086901 [ 3265 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.311837 [ 3272 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.315711 [ 3281 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.386979 [ 3269 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.448882 [ 3279 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.571361 [ 3276 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:17.606471 [ 3261 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.009452 [ 3294 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.095255 [ 3289 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.314486 [ 3291 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.318465 [ 3282 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.394823 [ 3301 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.451666 [ 3304 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.574342 [ 3303 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:18.609411 [ 3288 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.014856 [ 3322 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.099758 [ 3307 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.318440 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.320815 [ 3293 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.397597 [ 3319 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.454313 [ 3328 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.576951 [ 3310 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:19.613054 [ 3330 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.017415 [ 2826 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.102475 [ 2828 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.321579 [ 3325 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.323798 [ 2840 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.400977 [ 3335 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.459572 [ 2854 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.580346 [ 2852 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:20.616620 [ 2824 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.095450 [ 2838 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.105844 [ 2842 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.324914 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.327007 [ 2867 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.412312 [ 2862 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.468797 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.583527 [ 2869 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:21.661640 [ 2868 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.098467 [ 2877 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.108455 [ 2876 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.328007 [ 2874 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.329680 [ 2885 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.414742 [ 2878 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.471253 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.585938 [ 2889 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:22.664304 [ 2884 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.102070 [ 2900 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.149596 [ 2907 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.332120 [ 2911 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.334622 [ 2893 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.417707 [ 2897 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.474122 [ 2914 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.589081 [ 2916 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:23.666916 [ 2918 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.105084 [ 2932 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.152688 [ 2937 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.336445 [ 2936 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.337995 [ 2938 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.478651 [ 2947 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.481130 [ 2922 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.592207 [ 2933 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:24.669933 [ 2925 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.108175 [ 2949 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.155568 [ 2952 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.339324 [ 2953 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.341042 [ 2965 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.481693 [ 2970 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.484141 [ 2944 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.595792 [ 2976 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:25.673023 [ 2972 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.110813 [ 2969 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.158603 [ 2974 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.344899 [ 2980 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.348675 [ 2988 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.484297 [ 2987 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.487095 [ 2994 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.598086 [ 2986 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:26.675507 [ 2998 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.113905 [ 3002 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.161851 [ 3006 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.347880 [ 3017 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.351407 [ 3018 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.486703 [ 3015 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.489402 [ 3000 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.601141 [ 3022 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:27.678571 [ 3028 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.117428 [ 3029 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.164863 [ 3023 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.358780 [ 3037 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.360983 [ 3021 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.489805 [ 3046 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.492585 [ 3045 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.604649 [ 3040 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:28.681721 [ 3030 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.121709 [ 3057 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.167297 [ 3053 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.362643 [ 3050 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.364441 [ 3054 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.492762 [ 3062 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.495489 [ 3063 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.611664 [ 3064 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:29.684264 [ 3065 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.126086 [ 3075 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.169705 [ 3077 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.365282 [ 3083 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.367295 [ 3095 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.495792 [ 3098 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.498161 [ 3082 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.614629 [ 3100 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:30.687316 [ 3093 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.128857 [ 3107 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.172391 [ 3108 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.368292 [ 3120 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.370590 [ 3097 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.498730 [ 3124 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.502204 [ 3122 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.617360 [ 3118 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:31.690931 [ 3121 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.131923 [ 3123 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.175082 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.370987 [ 3141 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.373112 [ 3149 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.501617 [ 3148 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.505345 [ 3151 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.622890 [ 3153 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:32.693785 [ 3160 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.136993 [ 3164 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.177728 [ 3161 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.380113 [ 3170 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.383230 [ 3146 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.504477 [ 3177 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.508360 [ 3173 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.625559 [ 3171 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:33.697133 [ 3163 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.139127 [ 3181 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.186035 [ 3192 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.192224 [ 3187 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.385782 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.496064 [ 3197 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.508679 [ 3201 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.511854 [ 3193 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.631258 [ 3204 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:34.700094 [ 3218 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.141922 [ 3200 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.188342 [ 3202 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.388772 [ 3230 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.499052 [ 3222 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.511624 [ 3217 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.514558 [ 3226 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.634154 [ 3216 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:35.703157 [ 3228 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.144229 [ 3241 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.194656 [ 3246 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.397844 [ 3257 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.507778 [ 3251 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.514581 [ 3234 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.517581 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.645582 [ 3243 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:36.706686 [ 3245 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.180817 [ 4168 ] {f4852aaa-23bf-4f3c-88b8-14d453b8b5b1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41258) (comment: 02226_in_untuple_issue_34810.sql) (in query: DROP DATABASE IF EXISTS test_s0ri1t9k ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:28:37.183164 [ 4168 ] {f4852aaa-23bf-4f3c-88b8-14d453b8b5b1} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.203803 [ 3265 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.210386 [ 3263 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.326638 [ 12798 ] {77e32ff1-01bd-4a56-8d64-0db2e7de455a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52476) (comment: 02226_in_untuple_issue_34810.sql) (in query: DROP DATABASE IF EXISTS test_s0ri1t9k ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:28:37.335850 [ 12798 ] {77e32ff1-01bd-4a56-8d64-0db2e7de455a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.470848 [ 3280 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.511498 [ 3273 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.517190 [ 3279 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.520176 [ 3276 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.648939 [ 3286 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:37.712345 [ 3290 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.212212 [ 3297 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.212846 [ 3288 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.473777 [ 3311 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.516680 [ 3322 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.519888 [ 3307 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.523178 [ 3309 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.656110 [ 3324 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:38.724840 [ 3317 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.214319 [ 2822 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.215315 [ 3259 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.519203 [ 2845 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.522318 [ 2835 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.525663 [ 2823 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.561313 [ 2851 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.658820 [ 2840 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:39.727841 [ 2847 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.217594 [ 2825 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.218716 [ 2860 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.521565 [ 2857 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.525865 [ 2864 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.528926 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.566982 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.661472 [ 2865 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:40.732560 [ 2859 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.220692 [ 2880 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.221775 [ 2870 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.524787 [ 2875 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.529059 [ 2888 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.532080 [ 2889 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.569918 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.664557 [ 2902 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:41.735305 [ 2886 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.229397 [ 2898 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.229450 [ 2908 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.528000 [ 2920 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.531870 [ 2921 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.534645 [ 2923 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.572486 [ 2930 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.595948 [ 2764 ] {9cb6b7fb-0720-41dc-9ed5-dd6257cd9e07} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42570) (comment: 01764_collapsing_merge_adaptive_granularity.sql) (in query: SELECT sum(Sign), count() from collapsing_suspicious_granularity;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:28:42.602064 [ 2764 ] {9cb6b7fb-0720-41dc-9ed5-dd6257cd9e07} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:28:42.667532 [ 2932 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.740252 [ 2928 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:42.817719 [ 12798 ] {a04c5717-ab36-43a0-bda2-3bf8ef99fedc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52498) (comment: 01764_collapsing_merge_adaptive_granularity.sql) (in query: DROP DATABASE IF EXISTS test_hgg5lun5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:28:42.820869 [ 12798 ] {a04c5717-ab36-43a0-bda2-3bf8ef99fedc} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.232475 [ 2943 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.233221 [ 2935 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.530977 [ 2929 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.536795 [ 2945 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.537572 [ 2933 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.575853 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.670693 [ 2948 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:43.743685 [ 2952 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.235860 [ 2965 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.251522 [ 2959 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.537699 [ 2957 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.539577 [ 2968 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.540236 [ 2976 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.578689 [ 2971 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.679829 [ 2961 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.754109 [ 2962 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:44.994821 [ 3449 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ed6da895-e75e-431a-aa82-98915ef53fc9::202510_1_66_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.239326 [ 2991 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.253963 [ 2992 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.540358 [ 3004 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.541950 [ 3006 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.542865 [ 3001 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.581439 [ 3009 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.682201 [ 3014 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:45.756309 [ 3018 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.073585 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.242139 [ 3028 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.256530 [ 3012 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.543341 [ 3032 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.544911 [ 3020 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.545794 [ 3026 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.584709 [ 3025 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.689669 [ 3037 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:46.760141 [ 3046 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.244602 [ 3044 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.258816 [ 3053 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.389557 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.551542 [ 3043 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.552215 [ 3048 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.552849 [ 3042 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.587570 [ 3054 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.692739 [ 3063 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:47.762780 [ 3064 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.247271 [ 3073 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.261812 [ 3070 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.555124 [ 3077 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.561219 [ 3074 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.561323 [ 3083 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.590152 [ 3095 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.696424 [ 3067 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:48.766045 [ 3087 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.250187 [ 3102 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.264893 [ 3103 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.558721 [ 3110 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.565089 [ 3111 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.565805 [ 3116 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.593057 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.699522 [ 3127 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:49.769469 [ 3097 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.253677 [ 3130 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.268186 [ 3135 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.562079 [ 3134 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.567991 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.568993 [ 3123 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.595922 [ 3145 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.702900 [ 3137 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:50.772404 [ 3136 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.256307 [ 3143 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.270720 [ 3152 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.565765 [ 3155 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.571423 [ 3154 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.572544 [ 3161 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.599023 [ 3159 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.706339 [ 3170 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:51.776118 [ 3146 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.259000 [ 3169 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.274712 [ 3190 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.575347 [ 3179 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.575573 [ 3185 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.575749 [ 3192 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.602296 [ 3186 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.709821 [ 3189 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:52.779561 [ 3197 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.261512 [ 3196 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.277799 [ 3213 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.579950 [ 3200 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.580655 [ 3202 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.581668 [ 3199 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.608213 [ 3208 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.712920 [ 3210 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.782581 [ 3230 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:53.791298 [ 5620 ] {9222d995-bad4-44e8-be6e-d391205a3e9d} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.201802771 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57280) (comment: 03146_asof_join_ddb_merge_long.gen.sql) (in query: -- TODO: enable once USING and `join_use_nulls` is supported by `full_sorting_merge` -- SET join_use_nulls = 1; WITH build AS ( SELECT tk.number AS k, toDateTime('2021-01-01 00:00:00') + INTERVAL i.number SECONDS AS t, i.number % 37 AS v FROM numbers(3000000) AS i CROSS JOIN numbers(2) AS tk SETTINGS join_algorithm = 'hash', join_use_nulls = 0 ), probe AS ( SELECT tk.number AS k, toDateTime('2021-01-01 00:00:30') + INTERVAL tt.number HOUR AS t FROM numbers(2) AS tk CROSS JOIN numbers(toUInt32((toDateTime('2021-02-01 00:00:30') - toDateTime('2021-01-01 00:00:30')) / 3600)) AS tt SETTINGS join_algorithm = 'hash', join_use_nulls = 0 ) SELECT SUM(v) AS v, COUNT(*) AS n FROM probe ASOF LEFT JOIN build USING (k, t) ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:28:53.946863 [ 5620 ] {9222d995-bad4-44e8-be6e-d391205a3e9d} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.201802771 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:28:54.263991 [ 3238 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:54.281287 [ 3231 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:54.583708 [ 3227 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:54.584570 [ 3246 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:54.596193 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:54.613023 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:54.715989 [ 3244 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:54.785773 [ 3225 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.266817 [ 3239 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.284315 [ 3258 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.586478 [ 3267 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.587662 [ 3270 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.598955 [ 3248 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.615672 [ 3262 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.719424 [ 3281 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:55.788838 [ 3280 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.139991 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.270183 [ 3261 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.287672 [ 3287 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.589687 [ 3289 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.592084 [ 3290 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.602259 [ 3277 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.622414 [ 3283 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.723240 [ 3291 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:56.791696 [ 3301 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.311502 [ 3300 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.311615 [ 3295 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.592961 [ 3314 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.595865 [ 3322 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.605540 [ 3307 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.625734 [ 3309 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.726260 [ 3320 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:57.794849 [ 3324 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.313949 [ 3329 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.314705 [ 3326 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.595951 [ 2822 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.599200 [ 3259 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.609132 [ 3331 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.634027 [ 3334 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.729823 [ 2832 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:58.798475 [ 2828 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.401190 [ 2838 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.401300 [ 2856 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.600335 [ 2848 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.603176 [ 2853 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.613221 [ 2831 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.636989 [ 2846 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.734432 [ 2825 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:28:59.800919 [ 2860 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.409094 [ 2877 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.409160 [ 2876 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.603732 [ 2882 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.607807 [ 2880 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.616155 [ 2879 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.639485 [ 2861 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.737875 [ 2874 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:00.803986 [ 2885 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.411837 [ 2890 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.412336 [ 2886 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.606767 [ 2906 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.610861 [ 2899 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.618692 [ 2900 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.642780 [ 2895 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.740403 [ 2898 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:01.865866 [ 2892 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.414717 [ 2918 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.415167 [ 2930 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.609713 [ 2913 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.613843 [ 2932 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.621992 [ 2931 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.647331 [ 2937 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.743990 [ 2915 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:02.868945 [ 2936 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.421408 [ 2917 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.421907 [ 2940 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.612838 [ 2925 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.617429 [ 2941 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.626012 [ 2948 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.650797 [ 2949 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.746518 [ 2956 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:03.871811 [ 2964 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.432901 [ 2960 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.433412 [ 2957 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.616062 [ 2968 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.621036 [ 2972 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.629066 [ 2961 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.654504 [ 2969 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.749166 [ 2974 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:04.874886 [ 2981 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.112631 [ 12800 ] {1eb9249e-9c58-4bec-aa75-2cab9f26c1a9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46192) (comment: 03273_dictionary_rbac.sh) (in query: SELECT * FROM dict_03273_dictionary_rbac_test_15;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:29:05.122266 [ 12800 ] {1eb9249e-9c58-4bec-aa75-2cab9f26c1a9} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:29:05.435717 [ 2983 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.484431 [ 2986 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.619101 [ 2979 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.624214 [ 2993 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.632141 [ 3003 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.656937 [ 2980 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.752084 [ 2995 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:05.959152 [ 3004 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.441834 [ 2999 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.488206 [ 3000 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.622164 [ 3008 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.634539 [ 3022 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.635350 [ 3015 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.660063 [ 3012 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.831519 [ 3010 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:06.963201 [ 3024 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.071684 [ 2764 ] {03f6f91e-dbc4-44f4-97ae-f89f3bd5bd9a} 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.10521.altinitytest (altinity build)) (from [::1]:49310) (comment: 03273_dictionary_rbac.sh) (in query: SELECT * FROM dictionary(dict_03273_dictionary_rbac_test_15);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:29:07.087665 [ 2764 ] {03f6f91e-dbc4-44f4-97ae-f89f3bd5bd9a} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:29:07.444995 [ 3033 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.491086 [ 3037 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.625664 [ 3038 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.637917 [ 3046 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.638616 [ 3031 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.663202 [ 3045 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.910352 [ 3027 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:07.965940 [ 3047 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.079033 [ 2764 ] {8b5d1dc8-d88e-482e-b1b7-f112b0f54ae6} executeQuery: Code: 497. DB::Exception: user_03273_dictionary_rbac_test_15: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict_03273_dictionary_rbac_test_15: In scope SELECT dictGet(dict_03273_dictionary_rbac_test_15, 'value', 1). (ACCESS_DENIED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49338) (comment: 03273_dictionary_rbac.sh) (in query: SELECT dictGet(dict_03273_dictionary_rbac_test_15, 'value', 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dcbcd4 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000026dcb5f1 5. ./build_docker/./src/Access/ContextAccess.cpp:687: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000026dc9fce 6. ./build_docker/./src/Access/ContextAccess.cpp:756: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000026d96f1f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002852b14f 8. DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000b5d7f24 9. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d1f47 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 2025.10.15 20:29:08.094164 [ 2764 ] {8b5d1dc8-d88e-482e-b1b7-f112b0f54ae6} TCPHandler: Code: 497. DB::Exception: user_03273_dictionary_rbac_test_15: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_15.dict_03273_dictionary_rbac_test_15: In scope SELECT dictGet(dict_03273_dictionary_rbac_test_15, 'value', 1). (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dcbcd4 4. ./build_docker/./src/Access/ContextAccess.cpp:647: auto bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const::'lambda'(DB::AccessFlags, $T&&...)::operator()> const&, std::basic_string_view> const&>(DB::AccessFlags, $T&&...) const @ 0x0000000026dcb5f1 5. ./build_docker/./src/Access/ContextAccess.cpp:687: bool DB::ContextAccess::checkAccessImplHelper>, std::basic_string_view>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&, std::basic_string_view> const&) const @ 0x0000000026dc9fce 6. ./build_docker/./src/Access/ContextAccess.cpp:756: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x0000000026d96f1f 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000002852b14f 8. DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000b5d7f24 9. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d1f47 10. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 11. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 13. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 15. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 16. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 17. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 2025.10.15 20:29:08.447444 [ 3063 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.493869 [ 3069 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.629367 [ 3068 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.640768 [ 3065 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.641526 [ 3058 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.666026 [ 3085 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.756475 [ 2764 ] {2984c82b-0d84-4b36-b1f9-1b25c293de90} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49362) (comment: 03273_dictionary_rbac.sh) (in query: DROP TABLE IF EXISTS dict_table_03273_dictionary_rbac_test_15 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:29:08.764640 [ 2764 ] {2984c82b-0d84-4b36-b1f9-1b25c293de90} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:29:08.912415 [ 3061 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:08.968738 [ 3070 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.450649 [ 3098 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.498572 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.632309 [ 3091 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.643477 [ 3100 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.644116 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.668524 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.915424 [ 3102 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:09.971707 [ 3109 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.453254 [ 3105 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.501591 [ 3117 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.636073 [ 3097 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.646335 [ 3114 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.647064 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.673223 [ 3112 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.917848 [ 3118 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:10.976384 [ 3121 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.456471 [ 3123 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.504825 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.639120 [ 3148 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.649527 [ 3153 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.650653 [ 3151 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.676215 [ 3156 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.920989 [ 3162 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:11.980523 [ 3150 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.459661 [ 3159 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.508175 [ 3157 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.597255 [ 12800 ] {e0abb888-1f21-4749-9891-f7f867c413ac} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt64)): In scope SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map. (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:40: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794fa0a 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:12.609274 [ 12800 ] {e0abb888-1f21-4749-9891-f7f867c413ac} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt64)): In scope SELECT mapApply((k, v) -> tuple(v + 9223372036854775806), col) FROM table_map. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:40: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794fa0a 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:12.642277 [ 3167 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.652196 [ 3146 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.653864 [ 3168 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.678980 [ 3177 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.923937 [ 3166 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:12.983744 [ 3169 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.462832 [ 3183 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.511566 [ 3176 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.645535 [ 3181 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.660186 [ 3187 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.682401 [ 3186 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.748028 [ 3192 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.927101 [ 3189 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:13.987080 [ 3193 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.252991 [ 3204 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.465680 [ 3206 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.514838 [ 3209 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.648521 [ 3202 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.663446 [ 3199 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.685202 [ 3215 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.750915 [ 3208 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.930425 [ 3224 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:14.990059 [ 3230 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.469178 [ 3233 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.517817 [ 3214 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.651525 [ 3240 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.666707 [ 3227 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.688116 [ 3246 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.753368 [ 3236 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.933456 [ 3211 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:15.992595 [ 3243 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.297426 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.472076 [ 3271 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.520425 [ 3267 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.658339 [ 3250 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.669959 [ 3274 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.691313 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.756153 [ 3264 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.936674 [ 3273 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:16.995226 [ 3276 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.474438 [ 3277 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.523120 [ 3284 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.661233 [ 3282 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.673328 [ 3298 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.694156 [ 3304 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.758727 [ 3303 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.940231 [ 3288 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:17.998187 [ 3295 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:18.476960 [ 3321 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:18.526332 [ 3324 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:18.664316 [ 3317 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:18.676333 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:18.696873 [ 3319 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:18.761829 [ 3318 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:18.943447 [ 3328 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.004447 [ 3329 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.479991 [ 3332 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.531582 [ 2835 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.668358 [ 2823 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.679035 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.699847 [ 2847 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.764740 [ 2827 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:19.946654 [ 2852 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.007297 [ 2849 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.483258 [ 2825 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.535532 [ 2833 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.671784 [ 2862 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.688043 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.702968 [ 2864 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.768127 [ 2836 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:20.949430 [ 2859 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:21.010111 [ 2858 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:21.486623 [ 2879 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:21.538479 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:21.674804 [ 2885 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:21.690809 [ 2878 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:21.705990 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:21.771423 [ 2888 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.012549 [ 2902 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.048748 [ 2890 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.489162 [ 2904 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.541672 [ 2908 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.677558 [ 2893 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.693674 [ 2897 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.709079 [ 2912 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:22.774842 [ 2909 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.015667 [ 2923 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.051852 [ 2930 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.375184 [ 12800 ] {ce352a38-1d9b-47cf-8ae0-0707db7e48d9} executeQuery: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000aaafc3a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afda6e 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:23.385291 [ 12800 ] {ce352a38-1d9b-47cf-8ae0-0707db7e48d9} TCPHandler: Code: 42. DB::Exception: Function mapApply requires at least one argument, passed 0: In scope SELECT mapApply(). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000aaafc3a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afda6e 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:23.491519 [ 2947 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.543921 [ 2934 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.679784 [ 2929 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.696568 [ 2945 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.711884 [ 2933 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.777898 [ 2941 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:23.781061 [ 12800 ] {3d320788-4fc7-419a-b731-04e134b71d00} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(UInt8): In scope SELECT mapApply((x, y) -> x, map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:36: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794f984 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:23.783751 [ 12800 ] {3d320788-4fc7-419a-b731-04e134b71d00} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(UInt8): In scope SELECT mapApply((x, y) -> x, map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:36: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794f984 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:23.871950 [ 12800 ] {a69d049b-2334-41b3-8f5b-4c474e9b1ba3} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(String): In scope SELECT mapApply((x, y) -> 'x', map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> ('x'), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:36: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794f984 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:23.877221 [ 12800 ] {a69d049b-2334-41b3-8f5b-4c474e9b1ba3} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(String): In scope SELECT mapApply((x, y) -> 'x', map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:36: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794f984 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:24.018427 [ 2954 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.047504 [ 12800 ] {6b88a319-6326-4ccd-b25f-2a037a54f001} executeQuery: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt8, UInt8, UInt8)): In scope SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:40: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794fa0a 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:24.051209 [ 12800 ] {6b88a319-6326-4ccd-b25f-2a037a54f001} TCPHandler: Code: 36. DB::Exception: Expected Array(Tuple(key, value)) type, got Array(Tuple(UInt8, UInt8, UInt8)): In scope SELECT mapApply((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/DataTypes/DataTypeMap.cpp:40: DB::DataTypeMap::DataTypeMap(std::shared_ptr const&) @ 0x000000002794fa0a 5. std::shared_ptr std::allocate_shared[abi:v15007], std::shared_ptr, void>(std::allocator const&, std::shared_ptr&&) @ 0x00000000189e38a9 6. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018afd831 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:29:24.057153 [ 2964 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.499435 [ 2957 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.522037 [ 12800 ] {e19876fe-ea1b-495f-860b-5c7e74fdad30} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x, x + 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2c714 4. DB::MapAdapterBase, DB::NameMapApply>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000018b054df 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018afdc95 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:29:24.539225 [ 12800 ] {e19876fe-ea1b-495f-860b-5c7e74fdad30} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2c714 4. DB::MapAdapterBase, DB::NameMapApply>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000018b054df 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapApply>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018afdc95 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:29:24.547091 [ 2968 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.682810 [ 2961 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.699660 [ 2969 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.723369 [ 2984 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.820413 [ 2974 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:24.834856 [ 12800 ] {6f2becdb-7cb9-40cf-9b15-3ae30f29bea9} executeQuery: Code: 43. DB::Exception: Argument 2 of function arrayMap must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply(map(1, 0, 2, 0), (x, y) -> (x, x + 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000016194160 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018b03a4a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:24.838652 [ 12800 ] {6f2becdb-7cb9-40cf-9b15-3ae30f29bea9} TCPHandler: Code: 43. DB::Exception: Argument 2 of function arrayMap must be Array. Found Function((?, ?) -> ?) instead. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000016194160 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018b03a4a 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.021165 [ 2985 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.033749 [ 12800 ] {84edb868-1bbc-49a1-afca-d121975689c1} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapApply((x, y) -> (x, x+1), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000017110c31 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016c20ce9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283b0fbb 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839b5f6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:29:25.038997 [ 12800 ] {84edb868-1bbc-49a1-afca-d121975689c1} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000017110c31 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016c20ce9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283b0fbb 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839b5f6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:29:25.059816 [ 2975 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.228668 [ 12800 ] {8775218d-2a4a-4e5c-9a67-f7564f3fe324} executeQuery: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000aaafc3a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aecc4e 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.232401 [ 12800 ] {8775218d-2a4a-4e5c-9a67-f7564f3fe324} TCPHandler: Code: 42. DB::Exception: Function mapFilter requires at least one argument, passed 0: In scope SELECT mapFilter(). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000aaafc3a 4. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aecc4e 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.361972 [ 12800 ] {d98e0376-5005-4fd9-b383-70577f0f50de} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Int32: In scope SELECT mapFilter((x, y) -> toInt32(x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (toInt32(x)), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.367724 [ 12800 ] {d98e0376-5005-4fd9-b383-70577f0f50de} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Int32: In scope SELECT mapFilter((x, y) -> toInt32(x), map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.410770 [ 12800 ] {94266bb7-c70d-435b-83db-6e4213fd1c2e} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found String: In scope SELECT mapFilter((x, y) -> 'x', map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> ('x'), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.413778 [ 12800 ] {94266bb7-c70d-435b-83db-6e4213fd1c2e} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found String: In scope SELECT mapFilter((x, y) -> 'x', map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.463212 [ 12800 ] {03b15ead-e302-4264-97f4-fe3d7e0ef82b} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8)): In scope SELECT mapFilter(x -> (x, x), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x) -> (x, x), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.467221 [ 12800 ] {03b15ead-e302-4264-97f4-fe3d7e0ef82b} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(Tuple(UInt8, UInt8), Tuple(UInt8, UInt8)): In scope SELECT mapFilter(x -> (x, x), map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.502903 [ 2991 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.519244 [ 12800 ] {6d49286c-3624-4cf5-9296-da42d60087fb} executeQuery: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(UInt8, UInt8, UInt8): In scope SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.524468 [ 12800 ] {6d49286c-3624-4cf5-9296-da42d60087fb} TCPHandler: Code: 43. DB::Exception: Expression for function arrayFilter must return UInt8 or Nullable(UInt8), found Tuple(UInt8, UInt8, UInt8): In scope SELECT mapFilter((x, y) -> (x, 1, 2), map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018af3c1f 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018aec9ef 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.550649 [ 2996 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.686142 [ 2980 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.702663 [ 2995 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.726666 [ 2997 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.823633 [ 2990 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:25.934501 [ 12800 ] {cc34e086-3e03-4f9a-8b2c-1e311cd663e8} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (x, x + 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2c714 4. DB::MapAdapterBase, DB::NameMapFilter>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000018afc7df 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018aece75 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:29:25.940654 [ 12800 ] {cc34e086-3e03-4f9a-8b2c-1e311cd663e8} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2c714 4. DB::MapAdapterBase, DB::NameMapFilter>::extractNestedTypes(std::vector, std::allocator>>&) @ 0x0000000018afc7df 5. DB::FunctionMapToArrayAdapter, DB::MapToNestedAdapter, DB::NameMapFilter>::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018aece75 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.024157 [ 3014 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.052503 [ 12800 ] {1500046f-92d7-446d-89c0-6e60ddf08924} executeQuery: Code: 43. DB::Exception: Argument 2 of function arrayFilter must be Array. Found Function((?, ?) -> ?) instead. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter(map(1, 0, 2, 0), (x, y) -> (x > 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000016194160 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018af50ea 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.061394 [ 12800 ] {1500046f-92d7-446d-89c0-6e60ddf08924} TCPHandler: Code: 43. DB::Exception: Argument 2 of function arrayFilter must be Array. Found Function((?, ?) -> ?) instead. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long&&, String&&, String&&) @ 0x0000000016194160 4. DB::FunctionArrayMapped::getLambdaArgumentTypes(std::vector, std::allocator>>&) const @ 0x0000000018af50ea 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839a964 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.062849 [ 3011 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.107081 [ 12800 ] {f6f355ab-df81-4102-9591-e39b3afd3e58} executeQuery: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapFilter((x, y) -> (x, x + 1), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000017110c31 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016c20ce9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283b0fbb 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839b5f6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:29:26.111312 [ 12800 ] {f6f355ab-df81-4102-9591-e39b3afd3e58} TCPHandler: Code: 43. DB::Exception: Illegal types Tuple(UInt8, UInt8) and UInt8 of arguments of function plus: In scope (x, y) -> (x, x + 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000017110c31 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000016c20ce9 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2553: DB::QueryAnalyzer::resolveLambda(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::IdentifierResolveScope&) @ 0x00000000283b0fbb 16. ./contrib/llvm-project/libcxx/include/vector:961: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839b5f6 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:29:26.261130 [ 12800 ] {e9fbc5de-f1dc-4ce0-bf27-9e18bcd5b3e1} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt8, Tuple(UInt8, UInt8) because some of them are Tuple and some of them are not: In scope SELECT mapConcat([1, 2], map(1, 2)). (NO_COMMON_TYPE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapConcat([1, 2], map(1, 2));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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) @ 0x0000000027a79c55 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:402: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a836f0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a81768 6. DB::FunctionArrayConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018bd9066 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8f2f3 8. DB::FunctionMapToArrayAdapter, DB::NameMapConcat>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000189e284f 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:29:26.263569 [ 12800 ] {e9fbc5de-f1dc-4ce0-bf27-9e18bcd5b3e1} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt8, Tuple(UInt8, UInt8) because some of them are Tuple and some of them are not: In scope SELECT mapConcat([1, 2], map(1, 2)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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) @ 0x0000000027a79c55 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:402: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a836f0 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a81768 6. DB::FunctionArrayConcat::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000018bd9066 7. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8f2f3 8. DB::FunctionMapToArrayAdapter, DB::NameMapConcat>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000189e284f 9. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 10. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 11. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:29:26.447942 [ 12800 ] {512f8757-a50f-4081-be16-76f65b809dc5} executeQuery: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Tuple(UInt8, UInt8)): In scope SELECT mapSort(map(1, 2), map(3, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapSort(map(1, 2), map(3, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped, DB::NameArraySort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b22e26 5. DB::FunctionMapToArrayAdapter, DB::NameArraySort>, DB::MapToNestedAdapter, DB::NameMapSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b1de6f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.452190 [ 12800 ] {512f8757-a50f-4081-be16-76f65b809dc5} TCPHandler: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Tuple(UInt8, UInt8)): In scope SELECT mapSort(map(1, 2), map(3, 4)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped, DB::NameArraySort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b22e26 5. DB::FunctionMapToArrayAdapter, DB::NameArraySort>, DB::MapToNestedAdapter, DB::NameMapSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b1de6f 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.506286 [ 3010 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.553569 [ 3019 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.689404 [ 3032 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.706238 [ 3020 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.729881 [ 3026 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.772709 [ 12800 ] {cce50505-3f19-4873-a666-99cf8d8a9dfe} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapUpdate();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccda4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd4a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd55cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.776607 [ 12800 ] {cce50505-3f19-4873-a666-99cf8d8a9dfe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 0, should be 2: In scope SELECT mapUpdate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccda4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd4a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd55cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.825909 [ 3023 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:26.838554 [ 12800 ] {97757f4c-70eb-4c74-ab3b-193fa8282fa7} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0)). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49398) (comment: 02169_map_functions.sql) (in query: SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccda4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd4a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd55cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:26.843425 [ 12800 ] {97757f4c-70eb-4c74-ab3b-193fa8282fa7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapUpdate doesn't match: passed 3, should be 2: In scope SELECT mapUpdate(map(1, 3, 3, 2), map(1, 0, 2, 0), map(1, 0, 2, 0)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccda4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd4a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd55cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:29:27.026775 [ 3038 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:27.065452 [ 3031 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:27.509176 [ 3044 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:27.557086 [ 3053 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:27.699058 [ 3057 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:27.709190 [ 3052 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:27.732745 [ 3042 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:27.829543 [ 3050 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.032332 [ 3054 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.068706 [ 3059 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.512095 [ 3085 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.563754 [ 3071 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.702304 [ 3061 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.712179 [ 3056 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.735780 [ 3073 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:28.832113 [ 3090 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.035382 [ 3083 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.071188 [ 3080 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.478665 [ 2764 ] {395d041b-955a-4f3c-ac08-61cef71eec6c} executeQuery: Code: 57. DB::Exception: Table test_15.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35874) (comment: 03101_analyzer_invalid_join_on.sql) (in query: CREATE TABLE t1 (`c3` String) ENGINE = MergeTree PRIMARY KEY c3 SETTINGS index_granularity = 9640, min_bytes_for_wide_part = 895417152, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 84, min_bytes_for_full_part_storage = 510155525, compact_parts_max_bytes_to_buffer = 79201177, compact_parts_max_granules_to_buffer = 132, compact_parts_merge_max_bytes_to_prefetch_part = 19949250, merge_max_block_size = 20259, old_parts_lifetime = 425., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 847284, vertical_merge_algorithm_min_columns_to_activate = 94, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 30971070, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 11151, primary_key_compress_block_size = 93670), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:29:29.519654 [ 2764 ] {395d041b-955a-4f3c-ac08-61cef71eec6c} TCPHandler: Code: 57. DB::Exception: Table test_15.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:29:29.607557 [ 3093 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.607621 [ 3100 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.705536 [ 3086 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.721627 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.741368 [ 3108 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:29.834759 [ 3106 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.038153 [ 3110 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.073989 [ 3111 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.610374 [ 3097 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.619068 [ 3114 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.708677 [ 3124 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.724280 [ 3122 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.744297 [ 3113 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:30.840863 [ 3118 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.041558 [ 3135 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.076852 [ 3138 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.613989 [ 3149 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.621511 [ 3148 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.720970 [ 3156 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.727085 [ 3139 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.747207 [ 3143 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:31.844117 [ 3158 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.079423 [ 3154 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.131616 [ 3161 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.616866 [ 3146 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.633797 [ 3168 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.725857 [ 3177 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.730355 [ 3171 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.750830 [ 3174 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:32.847324 [ 3184 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.082041 [ 3172 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.134364 [ 3183 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.628753 [ 3180 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.636966 [ 3192 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.728716 [ 3197 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.733184 [ 3201 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.753550 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:33.850113 [ 3218 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.084504 [ 3205 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.143861 [ 3209 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.631825 [ 3220 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.640000 [ 3224 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.731949 [ 3221 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.736698 [ 3216 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.756811 [ 3229 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:34.855072 [ 3228 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.086707 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.146516 [ 3231 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.635050 [ 3232 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.642902 [ 3249 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.735756 [ 3225 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.739786 [ 3257 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.759908 [ 3251 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:35.857865 [ 3254 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.089037 [ 3253 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.151161 [ 3247 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.638344 [ 3281 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.646000 [ 3280 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.739373 [ 3264 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.743214 [ 3273 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.763286 [ 3279 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:36.861367 [ 3275 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.092090 [ 3292 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.154001 [ 3290 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.641585 [ 3288 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.649646 [ 3295 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.743037 [ 3296 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.747111 [ 3296 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.766742 [ 3299 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:37.864776 [ 3314 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.095193 [ 3309 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.156674 [ 3321 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.231309 [ 2764 ] {c131dfc0-7411-428e-846b-0b8ba977e7c5} executeQuery: Code: 450. DB::Exception: TTL expression result column should have Date, Date32, DateTime or DateTime64 type, but has Int32. (BAD_TTL_EXPRESSION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51372) (comment: 00933_alter_ttl.sql) (in query: alter table ttl modify ttl 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/TTLDescription.cpp:90: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000002bdc9ffd 5. ./build_docker/./src/Storages/TTLDescription.cpp:400: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000002bdcbd50 6. ./build_docker/./src/Storages/AlterCommands.cpp:801: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5f70f0 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b603f9c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49c610 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:29:38.234983 [ 2764 ] {c131dfc0-7411-428e-846b-0b8ba977e7c5} TCPHandler: Code: 450. DB::Exception: TTL expression result column should have Date, Date32, DateTime or DateTime64 type, but has Int32. (BAD_TTL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/TTLDescription.cpp:90: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000002bdc9ffd 5. ./build_docker/./src/Storages/TTLDescription.cpp:400: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000002bdcbd50 6. ./build_docker/./src/Storages/AlterCommands.cpp:801: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5f70f0 7. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b603f9c 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49c610 9. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:29:38.260100 [ 3438 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ed6da895-e75e-431a-aa82-98915ef53fc9::202510_1_71_14}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.351101 [ 3318 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.644843 [ 3331 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.654261 [ 2839 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.746613 [ 2832 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.757407 [ 3326 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.769883 [ 2826 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:38.868139 [ 2823 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.098043 [ 2847 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.159567 [ 2850 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.522395 [ 2764 ] {04822c81-602d-4e32-a183-b131220ef54d} executeQuery: Code: 43. DB::Exception: Illegal type Int32 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: While processing toDayOfMonth(d). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51372) (comment: 00933_alter_ttl.sql) (in query: alter table ttl modify column d Int ttl d + interval 1 day;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x00000000185f06d0 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDayOfMonthImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185ec515 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002824970d 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002878e5da 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000287a3e15 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000028792831 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002877a2ff 14. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000287302a1 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002874d95f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1815: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002874e153 17. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000002b6a4f6b 18. ./build_docker/./src/Storages/KeyDescription.cpp:75: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000002b6a4168 19. ./build_docker/./src/Storages/AlterCommands.cpp:1187: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b6040f6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49c610 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:29:39.537383 [ 2764 ] {04822c81-602d-4e32-a183-b131220ef54d} TCPHandler: Code: 43. DB::Exception: Illegal type Int32 of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: While processing toDayOfMonth(d). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::IFunctionDateOrDateTime::checkArguments(std::vector> const&, bool) const @ 0x00000000185f06d0 5. DB::FunctionDateOrDateTimeToSomething, DB::ToDayOfMonthImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x00000000185ec515 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002824970d 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002878e5da 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000287a3e15 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000028792831 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002877a2ff 14. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000287302a1 15. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x000000002874d95f 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:1815: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x000000002874e153 17. ./build_docker/./src/Storages/KeyDescription.cpp:0: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000002b6a4f6b 18. ./build_docker/./src/Storages/KeyDescription.cpp:75: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000002b6a4168 19. ./build_docker/./src/Storages/AlterCommands.cpp:1187: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b6040f6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49c610 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:29:39.656537 [ 2831 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.660111 [ 2846 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.677614 [ 2764 ] {4ec9a182-e087-4ddf-a456-e87bdf7e505e} executeQuery: Code: 524. DB::Exception: ALTER of key column d is forbidden. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51372) (comment: 00933_alter_ttl.sql) (in query: alter table ttl modify column d DateTime ttl d + interval 1 day;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3479: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a1e75 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:29:39.690469 [ 2764 ] {4ec9a182-e087-4ddf-a456-e87bdf7e505e} TCPHandler: Code: 524. DB::Exception: ALTER of key column d is forbidden. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3479: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a1e75 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:29:39.749739 [ 2860 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.760019 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.772409 [ 2862 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:39.871775 [ 2857 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.100750 [ 2863 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.162010 [ 2858 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.659499 [ 2873 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.663464 [ 2882 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.756809 [ 2829 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.775691 [ 2861 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.854320 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:40.874711 [ 2874 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.105703 [ 2894 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.165174 [ 2890 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.631366 [ 2764 ] {1a7bae9a-2aca-4a58-bd1f-b77ee4db55c8} executeQuery: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51424) (comment: 01017_in_unconvertible_complex_type.sql) (in query: -- When left and right element types are not compatible, we should get an error. select (toUInt8(1)) in ('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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e361a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaceaf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 6. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aadecb 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028454520 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000028451829 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839cb6b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:41.642970 [ 2764 ] {1a7bae9a-2aca-4a58-bd1f-b77ee4db55c8} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e361a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaceaf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 6. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aadecb 7. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028454520 8. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000028451829 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839cb6b 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:29:41.662444 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.666807 [ 2907 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.763804 [ 2898 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.861248 [ 2905 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.861663 [ 2903 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.878054 [ 2893 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:41.928586 [ 2764 ] {5a9d8f52-df60-4b46-b4c5-9c8f3c00a28d} executeQuery: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:51424) (comment: 01017_in_unconvertible_complex_type.sql) (in query: select [toUInt8(1)] in ['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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e361a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaceaf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa8794 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 8. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aadecb 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028454520 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000028451829 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839cb6b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:29:41.933252 [ 2764 ] {5a9d8f52-df60-4b46-b4c5-9c8f3c00a28d} TCPHandler: Code: 53. DB::Exception: Cannot convert string 'a' to type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e361a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaceaf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:0: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa8794 7. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 8. ./src/Core/Field.h:455: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&) @ 0x0000000029aadecb 9. ./contrib/llvm-project/libcxx/include/optional:344: DB::Block DB::(anonymous namespace)::createBlockFromCollection(DB::Array const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, bool) @ 0x0000000028454520 10. ./contrib/llvm-project/libcxx/include/vector:961: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, bool) @ 0x0000000028451829 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3398: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839cb6b 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:29:42.108340 [ 2930 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:42.168483 [ 2919 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:42.665004 [ 2936 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:42.669061 [ 2927 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:42.768414 [ 2938 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:42.864973 [ 2943 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:42.865954 [ 2926 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:42.881674 [ 2946 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.111386 [ 2940 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.171699 [ 2945 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.667969 [ 2953 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.671852 [ 2959 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.775351 [ 2950 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.868572 [ 2973 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.869379 [ 2960 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:43.885325 [ 2957 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.115140 [ 2972 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.174618 [ 2984 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.671850 [ 2988 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.678974 [ 2988 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.778622 [ 2982 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.873117 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.873330 [ 2998 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:44.888536 [ 2991 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.117921 [ 2980 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.177374 [ 2997 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.675381 [ 3011 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.682020 [ 3009 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.781932 [ 3007 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.876414 [ 3001 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.876953 [ 3008 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:45.891643 [ 3022 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.120969 [ 3024 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.179635 [ 3016 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.360096 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.679881 [ 3037 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.684877 [ 3030 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.785043 [ 3027 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.879791 [ 3044 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.880281 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:46.894717 [ 3051 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.123664 [ 3043 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.182476 [ 3042 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.683083 [ 3068 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.687827 [ 3066 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.788251 [ 3058 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.883249 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.883895 [ 3076 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:47.898301 [ 3072 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.126308 [ 3073 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.185321 [ 3084 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.686250 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.690849 [ 3094 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.791987 [ 3092 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.886601 [ 3088 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.887543 [ 3101 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:48.901855 [ 3093 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.130378 [ 3103 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.187851 [ 3109 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.689412 [ 3104 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.693796 [ 3120 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.795112 [ 3114 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.891148 [ 3112 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.891841 [ 3124 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:49.905808 [ 3122 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.133340 [ 3132 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.167380 [ 12800 ] {0f28cdee-d0b5-4733-802f-d9abe3872ccc} executeQuery: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40962) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (in query: SELECT ignore(toFixedString('Lambda as function parameter', 28), toNullable(28), ignore(8)), sum(marks) FROM system.parts WHERE database = currentDatabase() GROUP BY GROUPING SETS ((2)) FORMAT Null settings optimize_injective_functions_in_group_by=1, optimize_group_by_function_keys=1, group_by_use_nulls=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cd0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002842875a 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000028428f1b 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841f7ec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ffa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:50.170119 [ 12800 ] {0f28cdee-d0b5-4733-802f-d9abe3872ccc} TCPHandler: Code: 184. DB::Exception: Aggregate function sum(marks) is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cd0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002842875a 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000028428f1b 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841f7ec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ffa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:50.190552 [ 3138 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.692488 [ 3137 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.696773 [ 3142 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.798323 [ 3141 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.894001 [ 3149 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.894587 [ 3148 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:50.908653 [ 3139 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.136167 [ 3158 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.192967 [ 3147 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.699854 [ 3168 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.702684 [ 3177 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.801598 [ 3174 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.897465 [ 3166 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.898061 [ 3163 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:51.911750 [ 3169 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.139499 [ 3185 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.195062 [ 3179 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.706011 [ 3201 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.711626 [ 3197 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.804908 [ 3207 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.901092 [ 3218 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.901603 [ 3204 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:52.914427 [ 3196 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.143537 [ 3209 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.197933 [ 3226 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.520282 [ 12800 ] {48b5bb6a-e102-4cc6-acee-575c053f95e8} executeQuery: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40962) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (in query: SELECT count('Lambda as function parameter') AS c FROM (SELECT ignore(ignore('Lambda as function parameter', 28, 28, 28, 28, 28, 28), 28), materialize('Lambda as function parameter'), 28, 28, 'world', 5 FROM system.numbers WHERE ignore(materialize('Lambda as function parameter'), materialize(toLowCardinality(28)), 28, 28, 28, 28, toUInt128(28)) LIMIT 2) GROUP BY GROUPING SETS ((toLowCardinality(0)), (toLowCardinality(toNullable(28))), (1)) HAVING nullIf(c, 10) < 50 ORDER BY c ASC NULLS FIRST settings group_by_use_nulls=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cd0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002842875a 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000028428f1b 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841f7ec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ffa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:53.525341 [ 12800 ] {48b5bb6a-e102-4cc6-acee-575c053f95e8} TCPHandler: Code: 184. DB::Exception: Aggregate function count('Lambda as function parameter') AS c is found in GROUP BY in query. (ILLEGAL_AGGREGATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cd0ba 4. ./build_docker/./src/Analyzer/AggregationUtils.cpp:43: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x000000002842875a 5. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 6. ./src/Analyzer/InDepthQueryTreeVisitor.h:0: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000284285b5 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::assertNoAggregateFunctionNodes(std::shared_ptr const&, String const&) @ 0x0000000028428f1b 8. ./contrib/llvm-project/libcxx/include/string:1499: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000002841f7ec 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ffa7 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:29:53.708926 [ 3258 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.714621 [ 3253 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.808248 [ 3260 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.904510 [ 3265 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.905275 [ 3263 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:53.918008 [ 3267 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.145825 [ 3264 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.200374 [ 3279 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.393544 [ 12800 ] {76da1938-4d2c-4395-91c3-112ef1283b0e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40962) (comment: 03023_group_by_use_nulls_analyzer_crashes.sql) (in query: SELECT count(arraySplit(number -> toUInt8(number), [arraySplit(x -> toUInt8(number), [])])) FROM numbers(10) GROUP BY number, [number] WITH ROLLUP settings group_by_use_nulls=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad4dd97 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870303d 11. ./src/Functions/FunctionsMiscellaneous.h:0: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000282e1156 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x000000002ae407cc 17. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a36e967 18. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 19. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 23. ./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) @ 0x000000002825cda8 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002825a797 25. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9d2e77 26. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd9df39 27. ./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>>&) @ 0x0000000029440553 28. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029432f96 29. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 30. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 2025.10.15 20:29:54.400693 [ 12800 ] {76da1938-4d2c-4395-91c3-112ef1283b0e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(Nothing)) of argument of function toUInt8: while executing 'FUNCTION toUInt8(number :: 0) -> toUInt8(number) UInt8 : 1'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt8, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ad4dd97 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870303d 11. ./src/Functions/FunctionsMiscellaneous.h:0: DB::ExecutableFunctionExpression::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000282e1156 12. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 13. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 14. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 15. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ColumnFunction::reduce() const @ 0x000000002ae407cc 17. DB::FunctionArrayMapped, DB::NameArraySplit>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001a36e967 18. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 19. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 20. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 21. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 22. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 23. ./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) @ 0x000000002825cda8 24. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002825a797 25. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9d2e77 26. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dd9df39 27. ./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>>&) @ 0x0000000029440553 28. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029432f96 29. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 30. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 31. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 2025.10.15 20:29:54.717470 [ 3287 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.718080 [ 3277 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.811522 [ 3283 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.907882 [ 3301 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.908402 [ 3282 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:54.923521 [ 3298 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.148491 [ 3305 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.202995 [ 3306 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.721111 [ 3311 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.721611 [ 3321 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.815854 [ 3317 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.910755 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.911313 [ 3319 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:55.926319 [ 3318 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.150879 [ 2822 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.205819 [ 3331 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.724274 [ 2854 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.729011 [ 3335 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.819353 [ 3325 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.913670 [ 2849 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.914040 [ 2838 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:56.929640 [ 2842 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.153943 [ 2846 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.229353 [ 2860 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.727867 [ 2876 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.732387 [ 2877 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.822634 [ 2872 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.916952 [ 2871 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.917544 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:57.933144 [ 2866 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.156904 [ 2874 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.231783 [ 2883 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.508918 [ 4168 ] {827070a8-de6d-4940-9a03-2aa5e8c3b896} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60286) (comment: 00927_asof_join_correct_bt.sql) (in query: SELECT A.k, A.t, A.a, B.b, B.t, B.k FROM A ASOF LEFT JOIN B2 B USING(k,t) ORDER BY (A.k, A.t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:29:58.600637 [ 4168 ] {827070a8-de6d-4940-9a03-2aa5e8c3b896} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:29:58.731406 [ 2906 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.735362 [ 2899 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.825632 [ 2895 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.919879 [ 2898 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.920867 [ 2908 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:58.936385 [ 2905 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.159830 [ 2912 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.235104 [ 2910 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.734923 [ 2937 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.738345 [ 2932 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.828520 [ 2915 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.923088 [ 2927 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.924488 [ 2939 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:29:59.939665 [ 2943 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.162462 [ 2942 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.237525 [ 2948 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.738265 [ 2955 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.741146 [ 2953 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.831051 [ 2959 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.926200 [ 2950 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.928024 [ 2958 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:00.942638 [ 2944 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.165193 [ 2961 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.251221 [ 2969 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.611188 [ 3433 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a58126e5-943b-4092-9d19-33afc9a0cd35::202510_1_91_25}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.740990 [ 2983 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.743890 [ 2986 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.834031 [ 2992 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.928850 [ 2993 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.930389 [ 2996 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:01.945462 [ 3003 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.167791 [ 3011 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.254728 [ 3007 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.744021 [ 3028 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.749110 [ 3028 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.837627 [ 3019 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.931740 [ 3016 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.933157 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:02.948399 [ 3012 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.170469 [ 3036 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.257932 [ 3030 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.746627 [ 3041 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.751605 [ 3043 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.840796 [ 3050 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.935010 [ 3059 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.936786 [ 3048 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:03.950966 [ 3062 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.173188 [ 3064 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.260598 [ 3085 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.750031 [ 3084 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.755363 [ 3075 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.843889 [ 3080 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.939553 [ 3074 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.940120 [ 3098 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:04.953318 [ 3094 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:05.176211 [ 3092 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:05.263474 [ 3086 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:05.752940 [ 3109 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:05.758318 [ 3106 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:05.847267 [ 3110 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:05.999486 [ 3117 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:06.001400 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:06.002014 [ 3104 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:06.179138 [ 3128 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:06.267443 [ 3122 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:06.757615 [ 3138 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:06.761147 [ 3144 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:06.850612 [ 3135 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.002670 [ 3137 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.004140 [ 3140 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.005570 [ 3136 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.182705 [ 3160 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.269838 [ 3153 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.760650 [ 3170 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.763651 [ 3167 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:07.853867 [ 3146 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.058886 [ 3163 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.059590 [ 3169 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.060518 [ 3182 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.185453 [ 3172 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.272502 [ 3181 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.763659 [ 3192 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.767145 [ 3194 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:08.856771 [ 3201 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.062299 [ 3206 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.063154 [ 3219 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.064051 [ 3198 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.191077 [ 3191 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.275555 [ 3200 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.767199 [ 3230 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.773356 [ 3222 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:09.859888 [ 3229 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.065704 [ 3226 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.067543 [ 3214 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.068238 [ 3233 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.194556 [ 3246 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.278583 [ 3236 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.770533 [ 3256 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.776192 [ 3239 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:10.862375 [ 3258 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.076856 [ 3265 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.077028 [ 3263 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.077090 [ 3267 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.196958 [ 3250 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.281054 [ 3281 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.780564 [ 3275 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.780681 [ 3292 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:11.865724 [ 3294 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.079334 [ 3286 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.079952 [ 3291 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.081210 [ 3301 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.199336 [ 3288 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.284019 [ 3305 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.783567 [ 3312 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.784139 [ 3311 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:12.869514 [ 3320 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.082682 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.083796 [ 3319 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.084130 [ 3293 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.202610 [ 3313 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.286776 [ 3310 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.785885 [ 3328 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.786940 [ 2832 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:13.872687 [ 3326 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.085359 [ 2845 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.086701 [ 2835 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.087554 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.204743 [ 2854 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.289919 [ 3335 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.788597 [ 2856 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.790017 [ 2842 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:14.875839 [ 2846 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.088318 [ 2825 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.090452 [ 2860 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.090632 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.207772 [ 2857 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.292534 [ 2869 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.795666 [ 2841 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.796277 [ 2872 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:15.878472 [ 2844 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.091130 [ 2870 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.093049 [ 2879 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.097854 [ 2829 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.210920 [ 2882 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.294777 [ 2875 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.799287 [ 2906 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.804157 [ 2887 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:16.880594 [ 2900 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.094070 [ 2903 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.100457 [ 2897 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.101777 [ 2893 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.213764 [ 2911 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.297604 [ 2914 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.556342 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.802165 [ 2913 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.807008 [ 2931 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:17.883369 [ 2937 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.105886 [ 2926 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.107127 [ 2947 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.176649 [ 2946 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.216519 [ 2940 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.301018 [ 2933 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.805348 [ 2951 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.810155 [ 2954 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:18.886708 [ 2955 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.110363 [ 2958 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.113822 [ 2958 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.179175 [ 2973 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.226842 [ 2971 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.303672 [ 2972 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.809207 [ 2975 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.820471 [ 2988 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:19.889441 [ 2994 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.113228 [ 2998 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.117371 [ 2991 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.181689 [ 2993 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.229951 [ 2996 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.306810 [ 3003 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.811638 [ 3011 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.823436 [ 3009 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:20.892225 [ 2995 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.194057 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.195674 [ 3008 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.196267 [ 3022 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.233167 [ 3019 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.309680 [ 3016 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.814899 [ 3031 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.827496 [ 3045 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:21.916481 [ 3036 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.198865 [ 3039 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.199706 [ 3053 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.199955 [ 3044 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.236926 [ 3051 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.312811 [ 3047 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.817270 [ 3050 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.837300 [ 3054 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:22.919030 [ 3048 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.202362 [ 3069 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.203075 [ 3064 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.211284 [ 3068 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.244023 [ 3058 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.315958 [ 3063 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.820014 [ 3081 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.868899 [ 3061 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:23.921945 [ 3056 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.204977 [ 3080 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.205617 [ 3095 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.213919 [ 3089 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.246142 [ 3074 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.318054 [ 3091 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.823336 [ 3100 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.953167 [ 3108 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:24.953446 [ 3106 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:25.207820 [ 3117 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:25.208449 [ 3127 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:25.216376 [ 3079 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:25.248598 [ 3097 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:25.320086 [ 3119 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:25.826396 [ 3129 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.014165 [ 3144 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.014896 [ 3135 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.210385 [ 3131 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.210897 [ 3140 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.219339 [ 3137 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.252640 [ 3136 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.322241 [ 3148 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.423909 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:26.829196 [ 3154 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.017412 [ 3165 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.018091 [ 3150 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.212946 [ 3170 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.213545 [ 3167 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.222103 [ 3146 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.255149 [ 3171 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.324902 [ 3166 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:27.831198 [ 3174 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.020154 [ 3173 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.020671 [ 3179 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.216334 [ 3186 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.217400 [ 3194 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.224738 [ 3175 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.258165 [ 3189 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.327677 [ 3201 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:28.833987 [ 3191 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.022877 [ 3212 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.023236 [ 3223 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.219499 [ 3196 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.220186 [ 3220 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.227291 [ 3224 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.260979 [ 3221 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.330408 [ 3226 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:29.906318 [ 3227 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.025692 [ 3232 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.026607 [ 3238 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.221664 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.222632 [ 3244 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.229731 [ 3225 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.263723 [ 3257 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.332906 [ 3243 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:30.908926 [ 3265 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.028125 [ 3270 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.028938 [ 3271 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.224169 [ 3274 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.224862 [ 3272 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.232193 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.266398 [ 3280 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.335727 [ 3264 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:31.911995 [ 3278 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.030857 [ 3287 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.031568 [ 3286 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.226924 [ 3288 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.233999 [ 3303 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.234771 [ 3305 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.268599 [ 3306 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.343200 [ 3296 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:32.914787 [ 3266 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.038571 [ 3321 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.038741 [ 3324 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.229791 [ 3293 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.237291 [ 3318 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.238877 [ 3313 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.278570 [ 3322 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.345947 [ 3330 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:33.918009 [ 2845 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.041440 [ 2851 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.041970 [ 2828 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.233021 [ 3335 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.242605 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.241482 [ 2827 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.282029 [ 2852 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.349610 [ 2849 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:34.921006 [ 2855 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.044682 [ 2864 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.045163 [ 2869 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.236267 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.246192 [ 2863 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.265010 [ 2858 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.284995 [ 2865 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.352829 [ 2868 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:35.926920 [ 2871 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.047395 [ 2861 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.047913 [ 2881 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.239187 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.248917 [ 2888 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.267448 [ 2883 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.291720 [ 2894 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.355566 [ 2902 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:36.929892 [ 2895 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:37.050741 [ 2908 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:37.051415 [ 2891 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:37.242746 [ 2893 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:37.251610 [ 2911 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:37.270116 [ 2909 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:37.294853 [ 2914 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:37.358772 [ 2920 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.028240 [ 2932 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.053663 [ 2924 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.054185 [ 2915 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.246340 [ 2927 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.254598 [ 2938 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.273239 [ 2943 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.297890 [ 2926 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:38.362189 [ 2934 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.030527 [ 2935 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.056159 [ 2941 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.056582 [ 2949 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.250239 [ 2956 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.257478 [ 2953 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.280090 [ 2964 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.355227 [ 2952 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:39.365541 [ 2970 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.033057 [ 2968 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.058812 [ 2963 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.059422 [ 2978 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.253208 [ 2985 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.264342 [ 2988 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.283201 [ 2987 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.357577 [ 2989 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:40.369247 [ 2982 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.035868 [ 2996 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.061696 [ 3003 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.062725 [ 2980 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.256382 [ 3004 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.267213 [ 2990 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.285849 [ 3006 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.359754 [ 3011 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:41.371083 [ 3009 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.038752 [ 3023 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.064736 [ 3012 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.065983 [ 3026 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.259337 [ 3035 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.269821 [ 3025 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.288720 [ 3038 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.363163 [ 3033 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:42.374558 [ 3031 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.041613 [ 3039 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.069950 [ 3044 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.143494 [ 3051 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.263545 [ 3052 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.273134 [ 3042 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.292437 [ 3054 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.366816 [ 3048 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:43.377966 [ 3055 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.044439 [ 3059 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.072867 [ 3085 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.145941 [ 3076 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.266200 [ 3078 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.275640 [ 3061 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.295201 [ 3073 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.369771 [ 3090 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:44.380808 [ 3075 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.047250 [ 3088 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.075782 [ 3101 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.148587 [ 3093 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.268978 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.278021 [ 3099 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.297772 [ 3100 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.372735 [ 3106 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:45.383011 [ 3107 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.050920 [ 3113 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.078140 [ 3118 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.152443 [ 3120 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.273267 [ 3132 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.281387 [ 3130 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.301053 [ 3144 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.375816 [ 3134 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:46.386006 [ 3123 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.058692 [ 3156 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.080973 [ 3139 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.154919 [ 3158 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.276031 [ 3162 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.303019 [ 3147 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.304260 [ 3164 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.378965 [ 3151 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:47.389034 [ 3154 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.122477 [ 3166 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.123465 [ 3169 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.156904 [ 3184 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.278134 [ 3174 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.305944 [ 3183 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.306677 [ 3185 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.381889 [ 3173 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:48.391558 [ 3179 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.124953 [ 3193 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.134689 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.160434 [ 3207 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.281202 [ 3218 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.309527 [ 3209 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.356159 [ 3191 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.392370 [ 3202 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:49.394546 [ 3200 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.128048 [ 3231 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.137768 [ 3199 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.163668 [ 3222 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.291981 [ 3241 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.312239 [ 3252 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.359697 [ 3227 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.397368 [ 3232 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:50.404793 [ 3238 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.131244 [ 3211 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.140909 [ 3246 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.166774 [ 3243 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.294644 [ 3253 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.315008 [ 3258 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.363180 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.400183 [ 3267 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:51.413500 [ 3270 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.134319 [ 3273 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.145915 [ 3248 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.169745 [ 3279 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.297408 [ 3269 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.318035 [ 3276 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.367068 [ 3292 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.402939 [ 3261 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:52.416525 [ 3294 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.137386 [ 3298 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.148733 [ 3288 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.178052 [ 3303 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.300282 [ 3300 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.321619 [ 3297 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.370194 [ 3306 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.406069 [ 3296 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:53.505202 [ 3299 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.140321 [ 3317 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.151668 [ 3323 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.180531 [ 3293 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.320056 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.324984 [ 3322 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.384589 [ 3310 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.408606 [ 3330 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:54.509157 [ 3259 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.143028 [ 2828 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.154318 [ 2823 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.182946 [ 2850 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.266018 [ 3325 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.326041 [ 2838 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.327924 [ 2856 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.387002 [ 2842 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.412538 [ 2853 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:55.512072 [ 2846 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.150793 [ 2857 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.157414 [ 2864 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.185681 [ 2869 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.328837 [ 2865 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.330774 [ 2877 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.389485 [ 2848 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.416183 [ 2868 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:56.544155 [ 2841 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.154102 [ 2875 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.160279 [ 2888 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.188846 [ 2889 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.331735 [ 2886 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.333282 [ 2879 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.392349 [ 2901 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.419061 [ 2890 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:57.547233 [ 2906 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.156969 [ 2891 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.166329 [ 2903 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.192287 [ 2904 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.336249 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.337124 [ 2905 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.395800 [ 2914 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.422954 [ 2892 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:58.549439 [ 2910 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.159850 [ 2924 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.172027 [ 2915 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.194856 [ 2936 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.339062 [ 2926 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.339683 [ 2934 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.398839 [ 2922 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.425436 [ 2929 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:30:59.552372 [ 2925 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.162945 [ 2954 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.175102 [ 2955 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.198766 [ 2948 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.341317 [ 2964 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.341989 [ 2966 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.401015 [ 2970 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.427930 [ 2944 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:00.611549 [ 2973 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.165721 [ 2960 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.177916 [ 2974 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.201544 [ 2968 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.344122 [ 2981 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.393524 [ 2967 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.403603 [ 2969 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.432144 [ 2987 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:01.615278 [ 2994 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.169171 [ 2979 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.180883 [ 2993 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.204406 [ 2983 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.347391 [ 2980 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.396303 [ 3002 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.406650 [ 2990 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.435355 [ 3005 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.476251 [ 3448 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2d6955c1-12a8-48e1-8c31-9252f5a6aaec::202510_1_95_19}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:02.618879 [ 2999 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.174989 [ 3035 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.183513 [ 3016 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.207234 [ 3038 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.355850 [ 3031 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.399265 [ 3045 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.408954 [ 3037 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.438551 [ 3036 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:03.621706 [ 3040 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.177264 [ 3050 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.186303 [ 3060 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.210258 [ 3055 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.358898 [ 3065 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.402474 [ 3058 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.411737 [ 3085 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.441339 [ 3071 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:04.625093 [ 3081 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.180345 [ 3074 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.188971 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.212985 [ 3098 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.361824 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.405095 [ 3088 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.416341 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.444041 [ 3087 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:05.628106 [ 3103 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.183578 [ 3110 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.191746 [ 3111 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.215691 [ 3117 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.368222 [ 3120 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.408522 [ 3129 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.420405 [ 3121 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.448262 [ 3130 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:06.631305 [ 3144 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.186973 [ 3138 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.194879 [ 3148 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.218522 [ 3145 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.371555 [ 3143 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.412328 [ 3152 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.423402 [ 3158 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.450920 [ 3142 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:07.634708 [ 3162 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.189339 [ 3157 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.196955 [ 3170 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.221609 [ 3146 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.375133 [ 3168 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.415551 [ 3159 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.426489 [ 3163 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.453364 [ 3166 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:08.638619 [ 3190 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.191823 [ 3187 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.205631 [ 3178 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.224015 [ 3186 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.379316 [ 3192 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.420677 [ 3193 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.429979 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.456958 [ 3207 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:09.642265 [ 3195 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.194911 [ 3191 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.208407 [ 3202 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.226911 [ 3212 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.382625 [ 3210 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.424455 [ 3196 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.433101 [ 3220 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.460527 [ 3224 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.645203 [ 3199 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:10.669223 [ 3433 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c6436924-6aa9-401d-be8b-6811ef6366a4::202510_1_121_24}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.197773 [ 3238 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.210750 [ 3213 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.229659 [ 3236 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.385399 [ 3243 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.396464 [ 12800 ] {1eb14ee6-edd0-4744-a4f3-041751cb31e4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60264) (in query: select last_refresh_result from refreshes where view = 'c' -- 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:11.427320 [ 3254 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.435949 [ 3256 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.462901 [ 3245 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:11.474363 [ 12800 ] {1eb14ee6-edd0-4744-a4f3-041751cb31e4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:11.648100 [ 3258 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.200821 [ 3260 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.213101 [ 3250 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.232661 [ 3262 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.434737 [ 3264 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.438813 [ 3273 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.465777 [ 3248 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.481113 [ 3272 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.570852 [ 2764 ] {5a288d76-254c-4ce3-b4f8-314d812d70bc} executeQuery: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort([1, 2, 3]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60226) (comment: 00390_array_sort.sql) (in query: SELECT arrayPartialSort([1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&, unsigned long&&) @ 0x0000000018af7e66 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b34ca6 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:31:12.574325 [ 2764 ] {5a288d76-254c-4ce3-b4f8-314d812d70bc} TCPHandler: Code: 42. DB::Exception: Function arrayPartialSort needs at least 2 arguments, passed 1: In scope SELECT arrayPartialSort([1, 2, 3]). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&, unsigned long&&) @ 0x0000000018af7e66 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b34ca6 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:31:12.650817 [ 3275 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:12.793532 [ 2764 ] {65c9fa84-390c-44ab-b77a-16f07ace9efb} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], [1]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60226) (comment: 00390_array_sort.sql) (in query: SELECT arrayPartialSort(2, [1,2,3], [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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b34f4f 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:31:12.803313 [ 2764 ] {65c9fa84-390c-44ab-b77a-16f07ace9efb} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], [1]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b34f4f 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:31:12.927396 [ 2764 ] {1fb791ed-fb5c-4b6b-b5a2-5db1f70682ef} executeQuery: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60226) (comment: 00390_array_sort.sql) (in query: SELECT arrayPartialSort(2, [1,2,3], 3);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b34f4f 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:31:12.931461 [ 2764 ] {1fb791ed-fb5c-4b6b-b5a2-5db1f70682ef} TCPHandler: Code: 43. DB::Exception: First argument for function arrayPartialSort must be a function. Actual UInt8: In scope SELECT arrayPartialSort(2, [1, 2, 3], 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b34f4f 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:31:13.213638 [ 3287 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.216171 [ 3286 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.223496 [ 2764 ] {5db5abfb-3b6c-429c-a78e-5872562220e9} executeQuery: Code: 43. DB::Exception: Illegal type Array(UInt8) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayPartialSort(arraySort([1, 2, 3]), [1, 2, 3]). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60226) (comment: 00390_array_sort.sql) (in query: SELECT arrayPartialSort(arraySort([1,2,3]), [1,2,3]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. _ZN2DB13ArraySortImplILb1ELb1EE14checkArgumentsERKNSt3__112basic_stringIcNS2_11char_traitsIcEENS2_9allocatorIcEEEEPKNS_21ColumnWithTypeAndNameEQL_ZNS_13ArraySortImpl16num_fixed_paramsEE @ 0x0000000018b37382 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b3431a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:31:13.227344 [ 2764 ] {5db5abfb-3b6c-429c-a78e-5872562220e9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(UInt8) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayPartialSort(arraySort([1, 2, 3]), [1, 2, 3]). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. _ZN2DB13ArraySortImplILb1ELb1EE14checkArgumentsERKNSt3__112basic_stringIcNS2_11char_traitsIcEENS2_9allocatorIcEEEEPKNS_21ColumnWithTypeAndNameEQL_ZNS_13ArraySortImpl16num_fixed_paramsEE @ 0x0000000018b37382 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b3431a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:31:13.235448 [ 3282 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.364237 [ 2764 ] {8cd0e838-5b13-4637-89db-809486cc3846} executeQuery: Code: 43. DB::Exception: Illegal type Array(Array(UInt8)) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayMap(x -> range(x), [4, 1, 2, 3]) AS arr, 100 AS lim, arrayResize(arrayPartialSort(arrayPartialSort(lim, arr), arr), lim), arrayResize(arrayPartialReverseSort(lim, arr), lim), arrayResize(arrayPartialSort(x -> (-length(x)), lim, arr), lim). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60226) (comment: 00390_array_sort.sql) (in query: SELECT arrayMap(x -> range(x), [4, 1, 2, 3]) AS arr, 100 AS lim, arrayResize(arrayPartialSort(arrayPartialSort(lim, arr), arr), lim), arrayResize(arrayPartialReverseSort(lim, arr), lim), arrayResize(arrayPartialSort(x -> (-length(x)), lim, arr), lim);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. _ZN2DB13ArraySortImplILb1ELb1EE14checkArgumentsERKNSt3__112basic_stringIcNS2_11char_traitsIcEENS2_9allocatorIcEEEEPKNS_21ColumnWithTypeAndNameEQL_ZNS_13ArraySortImpl16num_fixed_paramsEE @ 0x0000000018b37382 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b3431a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:31:13.370145 [ 2764 ] {8cd0e838-5b13-4637-89db-809486cc3846} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Array(UInt8)) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayMap(x -> range(x), [4, 1, 2, 3]) AS arr, 100 AS lim, arrayResize(arrayPartialSort(arrayPartialSort(lim, arr), arr), lim), arrayResize(arrayPartialReverseSort(lim, arr), lim), arrayResize(arrayPartialSort(x -> (-length(x)), lim, arr), lim). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. _ZN2DB13ArraySortImplILb1ELb1EE14checkArgumentsERKNSt3__112basic_stringIcNS2_11char_traitsIcEENS2_9allocatorIcEEEEPKNS_21ColumnWithTypeAndNameEQL_ZNS_13ArraySortImpl16num_fixed_paramsEE @ 0x0000000018b37382 5. DB::FunctionArrayMapped, DB::NameArrayPartialSort>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000018b3431a 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:31:13.438063 [ 3298 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.441734 [ 3303 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.472533 [ 3305 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.483982 [ 3295 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.654068 [ 3297 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:13.777287 [ 2764 ] {6faa077b-860d-4528-ad0e-208ba99d9cbb} executeQuery: Code: 386. DB::Exception: There is no supertype for types UInt16, Int8, UInt8, String, UInt64 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60226) (comment: 00390_array_sort.sql) (in query: SELECT arrayPartialReverseSort(arraySort((x, y) -> y, [NULL, NULL], [NULL, NULL]), arr), arrayMap(x -> toString(x), [257, -9223372036854775807, 2, -2147483648, 2147483648, NULL, 65536, -2147483648, 2, 65535]) AS arr, NULL, 100 AS lim, 65536, arrayResize(arrayPartialSort(x -> reverse(x), lim, arr), lim) GROUP BY [NULL, 1023, -2, NULL, 255, '0', NULL, 9223372036854775806] WITH ROLLUP;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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) @ 0x0000000027a79c55 4. ./src/DataTypes/DataTypeDecimalBase.h:27: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a8376a 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a82aec 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:0: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000027a09831 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000001001f216 8. ./build_docker/./src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x00000000281ba11f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x0000000028321341 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000028301462 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:546: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000282ff896 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000028308ce2 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fe90e 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000028303cbe 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fe782 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x00000000282fde66 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029422cce 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:31:13.780111 [ 2764 ] {6faa077b-860d-4528-ad0e-208ba99d9cbb} TCPHandler: Code: 386. DB::Exception: There is no supertype for types UInt16, Int8, UInt8, String, UInt64 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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) @ 0x0000000027a79c55 4. ./src/DataTypes/DataTypeDecimalBase.h:27: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a8376a 5. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:0: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a82aec 6. ./build_docker/./src/DataTypes/FieldToDataType.cpp:0: DB::FieldToDataType<(DB::LeastSupertypeOnError)0>::operator()(DB::Array const&) const @ 0x0000000027a09831 7. auto DB::Field::dispatch, DB::Field&>(DB::FieldToDataType<(DB::LeastSupertypeOnError)0>&&, DB::Field&) @ 0x000000001001f216 8. ./build_docker/./src/Analyzer/ConstantNode.cpp:41: DB::ConstantNode::ConstantNode(DB::Field) @ 0x00000000281ba11f 9. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: std::shared_ptr std::allocate_shared[abi:v15007], DB::Field const&, void>(std::allocator const&, DB::Field const&) @ 0x0000000028321341 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:0: DB::(anonymous namespace)::QueryTreeBuilder::buildExpression(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000028301462 11. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:546: DB::(anonymous namespace)::QueryTreeBuilder::buildExpressionList(std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000282ff896 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000028308ce2 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fe90e 14. ./build_docker/./src/Analyzer/QueryTreeBuilder.cpp:0: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectWithUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x0000000028303cbe 15. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::(anonymous namespace)::QueryTreeBuilder::buildSelectOrUnionExpression(std::shared_ptr const&, bool, String const&, std::shared_ptr const&) const @ 0x00000000282fe782 16. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x00000000282fde66 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:131: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029422cce 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:31:14.216703 [ 3307 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:14.218869 [ 3309 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:14.237995 [ 3321 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:14.440340 [ 3313 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:14.443889 [ 3302 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:14.475672 [ 3320 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:14.486710 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:14.657560 [ 3316 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.219754 [ 2826 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.222008 [ 2840 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.241403 [ 2851 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.443127 [ 2823 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.446247 [ 2850 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.478820 [ 2854 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.489119 [ 3335 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:15.660977 [ 2830 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.226708 [ 2846 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.227722 [ 2831 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.245883 [ 2825 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.446589 [ 2869 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.449255 [ 2836 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.481685 [ 2863 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.492600 [ 2865 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.539697 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:16.666815 [ 2877 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.230590 [ 2881 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.231081 [ 2880 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.249989 [ 2866 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.449744 [ 2875 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.452078 [ 2888 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.484945 [ 2883 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.495987 [ 2889 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:17.669517 [ 2886 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.233398 [ 2897 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.233832 [ 2893 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.253076 [ 2911 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.453421 [ 2909 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.454839 [ 2892 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.492149 [ 2920 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.501776 [ 2923 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:18.672627 [ 2919 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.187549 [ 4168 ] {7095c5a7-e171-4486-96b6-3b98bcae730a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:42686) (in query: select last_refresh_result from refreshes where view = 'c' -- 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:19.194856 [ 4168 ] {7095c5a7-e171-4486-96b6-3b98bcae730a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:19.235769 [ 2926 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.236396 [ 2937 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.255909 [ 2946 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.456948 [ 2929 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.457866 [ 2939 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.496636 [ 2933 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.505119 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:19.676143 [ 2935 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.238451 [ 2965 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.239083 [ 2958 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.258808 [ 2976 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.460264 [ 2972 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.460573 [ 2959 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.500224 [ 2960 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.507866 [ 2974 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:20.679330 [ 2981 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.244699 [ 2982 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.245431 [ 2986 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.261541 [ 2979 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.462877 [ 2998 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.463651 [ 3003 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.503029 [ 2980 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.510488 [ 3002 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:21.681918 [ 2991 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.247652 [ 3013 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.251384 [ 3018 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.264144 [ 3022 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.465836 [ 3024 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.466376 [ 3010 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.505508 [ 3029 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.512715 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:22.700956 [ 3035 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.249934 [ 3037 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.253731 [ 3036 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.268589 [ 3040 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.468415 [ 3039 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.468915 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.508023 [ 3044 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.515113 [ 3034 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:23.703918 [ 3030 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.252682 [ 3062 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.256561 [ 3069 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.271580 [ 3064 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.472332 [ 3058 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.473158 [ 3085 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.511009 [ 3063 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.518000 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:24.707875 [ 3078 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.255814 [ 3074 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.259438 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.274906 [ 3098 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.476519 [ 3094 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.477222 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.514053 [ 3088 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.521227 [ 3101 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:25.711307 [ 3103 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.258527 [ 3111 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.262839 [ 3116 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.277795 [ 3109 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.480170 [ 3105 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.489825 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.517163 [ 3115 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.524520 [ 3128 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:26.714575 [ 3112 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.261956 [ 3126 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.265188 [ 3134 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.280609 [ 3123 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.483555 [ 3131 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.495568 [ 3140 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.520841 [ 3137 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.527430 [ 3149 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:27.718687 [ 3145 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.264397 [ 3164 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.267447 [ 3154 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.283504 [ 3155 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.486843 [ 3165 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.498855 [ 3161 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.523899 [ 3157 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.530352 [ 3170 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:28.725639 [ 3168 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.269946 [ 3183 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.272093 [ 3179 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.286994 [ 3185 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.490142 [ 3178 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.501723 [ 3186 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.527367 [ 3176 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.539511 [ 3180 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:29.728622 [ 3192 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.272030 [ 3189 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.275021 [ 3191 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.290736 [ 3202 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.492573 [ 3210 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.515202 [ 3196 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.533659 [ 3220 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.542530 [ 3224 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:30.731761 [ 3221 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.276963 [ 3222 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.280302 [ 3214 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.293362 [ 3229 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.495420 [ 3242 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.517471 [ 3240 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.537683 [ 3227 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.544965 [ 3232 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:31.734902 [ 3241 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.281385 [ 3256 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.282682 [ 3245 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.296115 [ 3253 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.498003 [ 3247 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.520351 [ 3265 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.540141 [ 3271 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.547244 [ 3260 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:32.738167 [ 3274 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.284451 [ 3276 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.285595 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.304370 [ 3292 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.500692 [ 3289 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.522891 [ 3277 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.548845 [ 3278 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.549904 [ 3290 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:33.742728 [ 3283 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.290749 [ 3299 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.290922 [ 3308 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.307482 [ 3314 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.503626 [ 3309 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.526056 [ 3324 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.551687 [ 3317 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.552622 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:34.746325 [ 3302 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.293187 [ 3331 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.293996 [ 3328 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.311274 [ 3326 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.506910 [ 2826 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.529053 [ 2851 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.559751 [ 2828 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.560121 [ 2823 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:35.750737 [ 2854 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.324191 [ 2842 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.324679 [ 2846 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.325196 [ 2831 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.509733 [ 2857 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.532862 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.562161 [ 2864 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.562491 [ 2836 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:36.753640 [ 2858 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.327645 [ 2861 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.328267 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.329314 [ 2880 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.512626 [ 2881 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.536498 [ 2874 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.564739 [ 2875 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.565416 [ 2888 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:37.756824 [ 2894 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.331567 [ 2884 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.332640 [ 2900 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.392855 [ 2899 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.515554 [ 2906 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.539445 [ 2903 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.567780 [ 2904 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.625168 [ 2897 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:38.817647 [ 2908 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.334733 [ 2919 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.335632 [ 2913 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.396006 [ 2928 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.518421 [ 2927 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.542560 [ 2943 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.570784 [ 2947 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.629501 [ 2916 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:39.820830 [ 2926 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.070002 [ 4168 ] {f8fe8f47-0af6-4186-9ed8-5a037157af2d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45446) (in query: select last_refresh_result from refreshes where view = 'c' -- 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:40.076360 [ 4168 ] {f8fe8f47-0af6-4186-9ed8-5a037157af2d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:40.337603 [ 2917 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.338372 [ 2949 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.399294 [ 2955 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.521699 [ 2951 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.546136 [ 2956 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.574591 [ 2952 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.633295 [ 2944 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:40.837603 [ 2958 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.059448 [ 3436 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ff640274-a70d-474b-b6eb-15ad6e6c74ba::202510_1_54_11}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.340164 [ 2967 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.340725 [ 2969 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.402422 [ 2988 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.524998 [ 2987 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.549387 [ 2985 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.584095 [ 2982 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.636918 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:41.841340 [ 2983 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.345670 [ 3011 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.355407 [ 3004 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.410670 [ 3009 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.527543 [ 2999 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.552302 [ 3013 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.586481 [ 3022 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.639529 [ 3015 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:42.844399 [ 3029 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.349101 [ 3025 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.358331 [ 3031 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.414480 [ 3037 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.530432 [ 3027 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.554815 [ 3039 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.589131 [ 3053 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.641957 [ 3044 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:43.682638 [ 4168 ] {65a2559b-6cc7-4b62-a9e9-e143911d91b2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45482) (in query: select last_refresh_result from refreshes where view = 'c' -- 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:43.689330 [ 4168 ] {65a2559b-6cc7-4b62-a9e9-e143911d91b2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:31:43.847082 [ 3043 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.355398 [ 3050 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.361276 [ 3042 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.417516 [ 3048 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.533042 [ 3068 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.557705 [ 3066 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.592470 [ 3065 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.644922 [ 3059 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:44.849573 [ 3063 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.359691 [ 3075 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.364657 [ 3083 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.421174 [ 3049 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.545538 [ 3089 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.560785 [ 3070 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.629041 [ 3074 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.647916 [ 3098 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:45.852608 [ 3092 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.363569 [ 3106 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.367813 [ 3107 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.426716 [ 3110 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.549080 [ 3109 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.569871 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.631939 [ 3097 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.652014 [ 3104 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.776474 [ 3448 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c6436924-6aa9-401d-be8b-6811ef6366a4::202510_1_126_25}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:46.854947 [ 3121 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.366292 [ 3149 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.370529 [ 3136 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.429818 [ 3138 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.552125 [ 3160 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.573369 [ 3156 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.636183 [ 3158 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.655607 [ 3153 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:47.858590 [ 3154 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.369364 [ 3167 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.373277 [ 3168 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.435031 [ 3163 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.555357 [ 3190 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.576553 [ 3188 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.639386 [ 3171 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.659058 [ 3181 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:48.861896 [ 3173 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.372193 [ 3193 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.375767 [ 3203 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.437469 [ 3205 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.558538 [ 3206 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.579357 [ 3218 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.642144 [ 3198 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.662397 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:49.864599 [ 3212 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.374978 [ 3216 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.379064 [ 3228 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.440259 [ 3230 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.561785 [ 3229 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.582330 [ 3233 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.645598 [ 3235 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.666965 [ 3252 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:50.867217 [ 3227 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.377813 [ 3251 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.382271 [ 3256 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.443254 [ 3253 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.565486 [ 3258 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.585698 [ 3247 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.648752 [ 3255 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.670170 [ 3270 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:51.870149 [ 3260 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.380655 [ 3269 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.384757 [ 3248 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.449160 [ 3285 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.568250 [ 3275 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.589204 [ 3292 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.652281 [ 3268 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.681470 [ 3261 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:52.873452 [ 3294 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.384042 [ 3300 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.387490 [ 3297 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.451523 [ 3306 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.571320 [ 3299 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.606870 [ 3308 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.656298 [ 3314 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.685005 [ 3266 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:53.876561 [ 3321 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.386309 [ 3331 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.390437 [ 3328 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.453883 [ 3332 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.573620 [ 2826 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.609452 [ 2828 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.658753 [ 2854 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.693147 [ 2847 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:54.879726 [ 2830 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.389379 [ 2825 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.392491 [ 2838 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.458359 [ 2833 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.575851 [ 2857 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.632676 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.661864 [ 2864 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.698268 [ 2836 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:55.883174 [ 2848 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.392352 [ 2844 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.395330 [ 2880 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.556155 [ 2866 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.578702 [ 2888 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.637176 [ 2883 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.664799 [ 2889 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.701519 [ 2885 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:56.886744 [ 2902 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.395518 [ 2906 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.399446 [ 2903 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.559410 [ 2904 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.582082 [ 2897 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.641146 [ 2911 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.667881 [ 2912 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.704546 [ 2908 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.754064 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:57.891170 [ 2923 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.400709 [ 2924 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.402291 [ 2932 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.562405 [ 2931 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.584366 [ 2943 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.643754 [ 2947 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.671091 [ 2916 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.707567 [ 2946 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:58.894577 [ 2929 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.403392 [ 2955 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.404889 [ 2941 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.565005 [ 2954 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.586914 [ 2952 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.646844 [ 2964 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.680091 [ 2973 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.710766 [ 2944 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:31:59.897448 [ 2965 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.406106 [ 2959 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.407861 [ 2960 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.568085 [ 2968 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.589676 [ 2962 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.650592 [ 2981 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.683461 [ 2967 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.713857 [ 2969 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:00.900246 [ 2985 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.410260 [ 2993 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.410554 [ 3003 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.570468 [ 3002 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.593265 [ 2990 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.653451 [ 3011 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.686393 [ 2991 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.716352 [ 3014 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:01.903788 [ 2999 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.412933 [ 3026 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.413643 [ 3020 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.573747 [ 3038 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.596567 [ 3035 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.656149 [ 3031 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.689545 [ 3037 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.719088 [ 3045 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:02.906267 [ 3021 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.415887 [ 3060 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.416530 [ 3042 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.576443 [ 3062 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.599183 [ 3066 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.659320 [ 3065 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.692609 [ 3059 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.725023 [ 3085 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:03.908629 [ 3081 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.418624 [ 3089 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.419230 [ 3070 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.579616 [ 3098 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.601779 [ 3084 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.662106 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.696079 [ 3101 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.728026 [ 3087 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:04.911909 [ 3102 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.423169 [ 3105 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.423571 [ 3115 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.584504 [ 3124 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.604678 [ 3129 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.664457 [ 3132 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.698797 [ 3135 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.808489 [ 3144 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:05.916509 [ 3134 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.425683 [ 3160 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.427902 [ 3156 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.587254 [ 3141 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.607344 [ 3162 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.669689 [ 3164 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.701809 [ 3155 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.811725 [ 3150 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:06.925709 [ 3170 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.428991 [ 3184 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.430452 [ 3190 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.591434 [ 3182 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.610110 [ 3181 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.672279 [ 3183 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.705170 [ 3185 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.816535 [ 3187 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:07.929196 [ 3176 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.434391 [ 3195 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.435100 [ 3219 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.597012 [ 3207 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.614873 [ 3198 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.675953 [ 3209 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.707744 [ 3200 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.819812 [ 3223 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:08.932170 [ 3224 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.436992 [ 3252 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.437365 [ 3242 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.599675 [ 3236 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.617201 [ 3241 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.678777 [ 3238 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.710323 [ 3211 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.822621 [ 3243 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:09.941849 [ 3245 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.440609 [ 3265 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.443354 [ 3270 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.602556 [ 3267 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.619685 [ 3264 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.681970 [ 3273 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.716171 [ 3279 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.827055 [ 3248 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:10.944935 [ 3285 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.443771 [ 3282 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.445991 [ 3288 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.605777 [ 3301 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.627575 [ 3300 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.685111 [ 3297 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.722586 [ 3306 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.830989 [ 3308 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:11.948351 [ 3266 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.446159 [ 3317 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.455063 [ 3293 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.608455 [ 3320 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.630554 [ 3329 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.688137 [ 3322 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.725597 [ 3331 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.835036 [ 3259 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:12.952163 [ 2832 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.448749 [ 2854 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.457313 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.610824 [ 2845 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.632999 [ 2842 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.690668 [ 2834 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.730409 [ 2862 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.838016 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:13.958060 [ 2843 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.170817 [ 2877 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.451900 [ 2870 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.460238 [ 2873 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.618254 [ 2861 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.636316 [ 2880 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.693440 [ 2866 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.733201 [ 2875 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.843612 [ 2886 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:14.965988 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.455613 [ 2898 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.465305 [ 2906 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.621512 [ 2911 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.639567 [ 2893 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.736334 [ 2905 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.736930 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.846280 [ 2919 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:15.969141 [ 2914 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.458469 [ 2943 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.468348 [ 2938 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.624980 [ 2937 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.642589 [ 2946 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.703544 [ 12798 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.749060 [ 2922 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.749430 [ 2929 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.849746 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:16.972290 [ 2939 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.460934 [ 2952 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.470916 [ 2951 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.629094 [ 2973 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.645607 [ 2944 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.708723 [ 4168 ] {84447d84-abbb-4b8f-8f3b-dcf35b7bcc13} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:33254) (in query: select last_refresh_result from refreshes where view = 'c' -- 23), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:32:17.728736 [ 4168 ] {84447d84-abbb-4b8f-8f3b-dcf35b7bcc13} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:32:17.752611 [ 2958 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.752970 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.863639 [ 2972 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:17.987057 [ 2950 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:18.464685 [ 2982 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:18.473113 [ 2986 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:18.632623 [ 2979 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:18.649167 [ 2996 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:18.756395 [ 2997 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:18.770504 [ 3002 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:18.906454 [ 3011 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.082331 [ 3009 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.468007 [ 3019 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.476048 [ 3001 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.635880 [ 3000 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.652830 [ 3026 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.760216 [ 3016 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.773795 [ 3033 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:19.909875 [ 3031 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.085556 [ 3021 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.471403 [ 3041 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.479564 [ 3054 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.639005 [ 3050 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.656267 [ 3060 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.766818 [ 3055 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.777376 [ 3055 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:20.914027 [ 3065 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.089086 [ 3063 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.475159 [ 3095 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.483284 [ 3083 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.645060 [ 3070 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.659725 [ 3067 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.777219 [ 3077 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.780854 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:21.918170 [ 3094 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.092245 [ 3103 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.479031 [ 3116 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.489114 [ 3110 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.648633 [ 3097 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.663565 [ 3104 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.780198 [ 3105 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.783615 [ 3115 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:22.921649 [ 3128 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.095375 [ 3113 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.484338 [ 3121 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.493261 [ 3144 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.652443 [ 3125 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.668337 [ 3131 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.783475 [ 3140 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.789179 [ 3123 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:23.925040 [ 3148 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.098936 [ 3156 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.487680 [ 3142 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.570149 [ 3147 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.655553 [ 3150 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.671795 [ 3165 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.786802 [ 3161 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.792682 [ 3157 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:24.928666 [ 3146 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.107837 [ 3166 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.492481 [ 3174 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.573581 [ 3181 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.661536 [ 3179 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.675282 [ 3185 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.790469 [ 3187 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.796201 [ 3178 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:25.932916 [ 3176 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.111279 [ 3194 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.496663 [ 3189 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.577403 [ 3191 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.665005 [ 3215 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.681048 [ 3223 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.794309 [ 3196 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.800788 [ 3220 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.910573 [ 3441 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a58126e5-943b-4092-9d19-33afc9a0cd35::202510_1_112_37}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:26.941529 [ 3221 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.113775 [ 3237 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.499653 [ 3232 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.580878 [ 3241 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.674036 [ 3249 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.684535 [ 3213 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.797085 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.808727 [ 3225 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:27.858147 [ 16545 ] {278883ce-8951-41b8-b36a-27df5b3283b9} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.0367305 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35478) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:27.894748 [ 16545 ] {278883ce-8951-41b8-b36a-27df5b3283b9} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.0367305 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:27.944604 [ 3251 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.116456 [ 3254 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.502876 [ 3271 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.583790 [ 3260 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.679850 [ 3267 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.694039 [ 3281 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.800841 [ 3263 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.869914 [ 3264 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:28.948099 [ 3248 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.119594 [ 3280 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.506919 [ 12800 ] {80159de2-9696-4e2f-84cd-712c307660ed} executeQuery: std::exception. Code: 1001, type: avro::Exception, e.what() = Cannot read compressed data, expected at least 4 bytes, got 0 (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35510) (comment: 02373_heap_buffer_overflow_in_avro.sh) (in query: select * from file(corrupted.avro)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(String const&) @ 0x000000003a0d134e 1. ./contrib/avro/lang/c++/api/Exception.hh:37: avro::DataFileReaderBase::readDataBlock() @ 0x0000000036ab3ff5 2. ./build_docker/./contrib/avro/lang/c++/impl/DataFile.cc:0: avro::DataFileReaderBase::hasMore() @ 0x0000000036ab4e60 3. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:0: DB::AvroRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d41f3be 4. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 7. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b79f55e 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:32:29.508781 [ 3291 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.541489 [ 12800 ] {80159de2-9696-4e2f-84cd-712c307660ed} TCPHandler: Code: 1001. DB::Exception: avro::Exception: Cannot read compressed data, expected at least 4 bytes, got 0. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: std::runtime_error::runtime_error(String const&) @ 0x000000003a0d134e 1. ./contrib/avro/lang/c++/api/Exception.hh:37: avro::DataFileReaderBase::readDataBlock() @ 0x0000000036ab3ff5 2. ./build_docker/./contrib/avro/lang/c++/impl/DataFile.cc:0: avro::DataFileReaderBase::hasMore() @ 0x0000000036ab4e60 3. ./build_docker/./src/Processors/Formats/Impl/AvroRowInputFormat.cpp:0: DB::AvroRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d41f3be 4. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47e645 5. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 6. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 7. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 11. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 12. ./build_docker/./src/Storages/StorageFile.cpp:1454: DB::StorageFileSource::generate() @ 0x000000002b79f55e 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:32:29.587527 [ 3268 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.683334 [ 3283 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.697376 [ 3298 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.803843 [ 3305 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.873849 [ 3295 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:29.991328 [ 3303 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.085037 [ 16545 ] {0e7095ff-7d2e-45af-ba79-5e7f60178cc7} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.132862132 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35498) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:30.129489 [ 3308 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.134525 [ 16545 ] {0e7095ff-7d2e-45af-ba79-5e7f60178cc7} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.132862132 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:30.149678 [ 16846 ] {d7496fba-f974-4d8d-8722-fd759413a98c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:46984). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46984) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bcb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d19ee4e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d187237 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:32:30.151080 [ 16736 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:50578, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d185ab3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.164509 [ 4168 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51822, local: [::ffff:127.0.0.3]: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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d185ab3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.186149 [ 16846 ] {d7496fba-f974-4d8d-8722-fd759413a98c} 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]:46984). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.197379 [ 16846 ] {d7496fba-f974-4d8d-8722-fd759413a98c} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:46984). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bcb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d19ee4e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d187237 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:32:30.201566 [ 16846 ] {d7496fba-f974-4d8d-8722-fd759413a98c} TCPHandler: Client has gone away. 2025.10.15 20:32:30.512472 [ 3311 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.591070 [ 3317 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.686839 [ 3319 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.708678 [ 3313 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.807465 [ 3323 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.891709 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:30.995135 [ 3322 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.161163 [ 3326 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.515469 [ 3334 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.594321 [ 2823 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.691339 [ 2847 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.712159 [ 3335 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.810911 [ 2835 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.895461 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:31.999103 [ 2849 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:32.164671 [ 2827 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:32.518745 [ 2825 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:32.598124 [ 2834 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:32.694889 [ 2857 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:32.715816 [ 2867 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:32.814623 [ 2869 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:32.898909 [ 2864 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.004990 [ 2863 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.168023 [ 2877 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.523507 [ 2871 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.601616 [ 2873 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.708316 [ 2880 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.719680 [ 2844 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.838012 [ 2874 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:33.902757 [ 2866 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.008232 [ 2902 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.171973 [ 2878 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.528710 [ 2895 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.605919 [ 2899 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.685827 [ 16551 ] {fd567e1f-9c53-4e51-9a7a-a76f231c7fba} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35566) (comment: 01825_type_json_missed_values.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:32:34.716509 [ 2903 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.721453 [ 16551 ] {fd567e1f-9c53-4e51-9a7a-a76f231c7fba} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:32:34.722975 [ 2904 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.861759 [ 2911 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.905891 [ 2908 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:34.922062 [ 16545 ] {4c98dd3a-e8fc-4dda-b5a1-750c76ab6a07} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column ParsedParams.Key1): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_1_10_1/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 25123): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35534) (comment: 00053_replicate_segfault.sql) (in query: SELECT count() > 0 FROM (SELECT ParsedParams.Key1 AS p FROM test.visits WHERE arrayAll(y -> arrayExists(x -> y != x, p), p)) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b583216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762d10 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000277676c1 15. DB::ReadBuffer::next() @ 0x000000000b52aaeb 16. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b583216 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c14f04 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c12580 19. ./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 @ 0x0000000027aa3a5b 20. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::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 @ 0x0000000027b79078 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027abdbc1 22. ./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) @ 0x000000002c80c27e 23. ./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>>&) @ 0x000000002c80afed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002deb5454 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 31. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 2025.10.15 20:32:34.949044 [ 16545 ] {4c98dd3a-e8fc-4dda-b5a1-750c76ab6a07} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): (while reading column ParsedParams.Key1): (while reading from part /var/lib/clickhouse/store/4b8/4b83d4cf-967a-458a-8c21-031a038dc9d0/201403_1_10_1/ in table test.visits (4b83d4cf-967a-458a-8c21-031a038dc9d0) located on disk default of type local, from mark 0 with max_rows_to_read = 25123): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b583216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762d10 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000277676c1 15. DB::ReadBuffer::next() @ 0x000000000b52aaeb 16. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b583216 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:0: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c14f04 18. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c12580 19. ./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 @ 0x0000000027aa3a5b 20. ./build_docker/./src/DataTypes/Serializations/SerializationNamed.cpp:0: DB::SerializationNamed::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 @ 0x0000000027b79078 21. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027abdbc1 22. ./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) @ 0x000000002c80c27e 23. ./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>>&) @ 0x000000002c80afed 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002deb5454 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 31. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 2025.10.15 20:32:35.011364 [ 2920 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.175234 [ 2919 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.532293 [ 2932 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.608786 [ 2931 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.680453 [ 4168 ] {52aad547-1210-46a9-b89d-27a356f3de95} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.167378868 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35582) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:35.724851 [ 2938 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.726617 [ 2915 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.773634 [ 16871 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:33154, local: [::ffff:127.0.0.5]: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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d185ab3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.789890 [ 4168 ] {52aad547-1210-46a9-b89d-27a356f3de95} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.167378868 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:35.810438 [ 12800 ] {2162a8e2-adbf-4e24-8325-b6cf8780ad1a} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:40784). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40784) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:35.778192 [ 16736 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:46384, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d185ab3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.821794 [ 2764 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:40812, local: [::ffff:127.0.0.3]: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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d185ab3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.825353 [ 16551 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:36782, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d185ab3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.832545 [ 12800 ] {2162a8e2-adbf-4e24-8325-b6cf8780ad1a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:40784). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.853941 [ 12800 ] {2162a8e2-adbf-4e24-8325-b6cf8780ad1a} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:40784). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:35.863652 [ 12800 ] {2162a8e2-adbf-4e24-8325-b6cf8780ad1a} TCPHandler: Client has gone away. 2025.10.15 20:32:35.864531 [ 2926 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.909530 [ 2934 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.984490 [ 16872 ] {d50b4c2a-9a56-4806-8824-7764bf07e294} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:46278). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46278) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bcb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:35.985042 [ 12798 ] {1a3f72b4-b71f-4c22-bb05-bd5ac0652ccf} 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]:37202). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37202) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:35.992492 [ 12798 ] {1a3f72b4-b71f-4c22-bb05-bd5ac0652ccf} 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]:37202). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:35.996606 [ 12798 ] {1a3f72b4-b71f-4c22-bb05-bd5ac0652ccf} 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]:37202). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:36.000809 [ 12798 ] {1a3f72b4-b71f-4c22-bb05-bd5ac0652ccf} TCPHandler: Client has gone away. 2025.10.15 20:32:36.014281 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.068544 [ 16872 ] {d50b4c2a-9a56-4806-8824-7764bf07e294} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:46278). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.076834 [ 16872 ] {d50b4c2a-9a56-4806-8824-7764bf07e294} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:46278). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bcb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:36.086089 [ 16872 ] {d50b4c2a-9a56-4806-8824-7764bf07e294} TCPHandler: Client has gone away. 2025.10.15 20:32:36.178834 [ 2935 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.215143 [ 16846 ] {2cf82361-5948-4a66-a5c1-076cf3590a85} executeQuery: Code: 57. DB::Exception: Table test.hits_snippet already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36862) (comment: 00071_merge_tree_optimize_aio.sql) (in query: CREATE TABLE test.hits_snippet(EventTime DateTime('Asia/Dubai'), EventDate Date, CounterID UInt32, UserID UInt64, URL String, Referer String) ENGINE = MergeTree(EventDate, intHash32(UserID), (CounterID, EventDate, intHash32(UserID), EventTime), 8192);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:32:36.256091 [ 16846 ] {2cf82361-5948-4a66-a5c1-076cf3590a85} TCPHandler: Code: 57. DB::Exception: Table test.hits_snippet already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:32:36.535141 [ 2956 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.623777 [ 2970 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.728233 [ 2973 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.729650 [ 2944 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.867488 [ 2958 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.913792 [ 2966 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:36.950828 [ 16551 ] {0c76e50f-302d-4c54-b8fc-54d04c677949} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36876) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:32:36.967449 [ 16551 ] {0c76e50f-302d-4c54-b8fc-54d04c677949} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:32:37.017336 [ 2959 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.181924 [ 2960 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.529951 [ 16551 ] {1548031b-b0cd-47f7-b384-438795d816c9} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36876) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 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) @ 0x000000000ad4d0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab010b5 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 29. ./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&) @ 0x000000002942671d 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 2025.10.15 20:32:37.538018 [ 2981 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.541494 [ 16551 ] {1548031b-b0cd-47f7-b384-438795d816c9} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 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) @ 0x000000000ad4d0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab010b5 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 29. ./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&) @ 0x000000002942671d 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 2025.10.15 20:32:37.626797 [ 2977 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.732668 [ 2975 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.734297 [ 2994 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.762859 [ 16551 ] {1054ab33-7e23-4c47-b45f-46d78ee3e28f} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (CANNOT_CONVERT_TYPE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36876) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT toIntervalSecond(now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:32:37.769746 [ 16551 ] {1054ab33-7e23-4c47-b45f-46d78ee3e28f} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT toIntervalSecond(now64()). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 9. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:32:37.836805 [ 4168 ] {f0714b98-74c6-4f83-a3c9-264288308d07} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.17300259 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36878) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:37.870749 [ 2985 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.889864 [ 4168 ] {f0714b98-74c6-4f83-a3c9-264288308d07} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.17300259 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:32:37.917316 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:37.919085 [ 16551 ] {84439869-8507-4606-9859-bd807281c95c} executeQuery: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (CANNOT_CONVERT_TYPE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36876) (comment: 01291_unsupported_conversion_from_decimal.sql) (in query: SELECT CAST(now64() AS IntervalSecond);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 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) @ 0x000000000ad4d0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab010b5 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 29. ./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&) @ 0x000000002942671d 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 2025.10.15 20:32:37.930198 [ 16551 ] {84439869-8507-4606-9859-bd807281c95c} TCPHandler: Code: 70. DB::Exception: Unsupported data type in conversion function: In scope SELECT CAST(now64(), 'IntervalSecond'). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. bool DB::callOnIndexAndDataType::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000b269eca 5. DB::(anonymous namespace)::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b259ff6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aac9d8f 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) @ 0x000000000ad4d0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 13. DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ab010b5 14. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 15. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 17. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 18. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 19. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 26. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 27. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 29. ./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&) @ 0x000000002942671d 30. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 2025.10.15 20:32:38.015343 [ 16958 ] {a4b9f7da-db71-4085-84d6-347cacf8900d} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:59432). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59432) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:38.019924 [ 2989 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.022477 [ 16958 ] {a4b9f7da-db71-4085-84d6-347cacf8900d} 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]:59432). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.027756 [ 16958 ] {a4b9f7da-db71-4085-84d6-347cacf8900d} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:59432). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:38.034332 [ 16958 ] {a4b9f7da-db71-4085-84d6-347cacf8900d} TCPHandler: Client has gone away. 2025.10.15 20:32:38.045559 [ 16960 ] {4571f466-4c9e-4193-8b76-9e99c9611c69} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:53778). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53778) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:38.074302 [ 16960 ] {4571f466-4c9e-4193-8b76-9e99c9611c69} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:53778). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.080863 [ 2764 ] {c3739ce9-ab6e-41bb-9046-e4daa8385fea} 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]:37208). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37208) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:38.081440 [ 16960 ] {4571f466-4c9e-4193-8b76-9e99c9611c69} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:53778). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:38.085914 [ 16960 ] {4571f466-4c9e-4193-8b76-9e99c9611c69} TCPHandler: Client has gone away. 2025.10.15 20:32:38.091308 [ 2764 ] {c3739ce9-ab6e-41bb-9046-e4daa8385fea} 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]:37208). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.096589 [ 2764 ] {c3739ce9-ab6e-41bb-9046-e4daa8385fea} 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]:37208). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:32:38.105281 [ 2764 ] {c3739ce9-ab6e-41bb-9046-e4daa8385fea} TCPHandler: Client has gone away. 2025.10.15 20:32:38.185464 [ 2996 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.541407 [ 3018 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.630350 [ 3024 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.737022 [ 3028 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.737868 [ 3019 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.873624 [ 3023 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:38.921222 [ 3032 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.028479 [ 3026 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.190559 [ 3020 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.545414 [ 3037 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.635655 [ 3040 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.740174 [ 3039 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.741248 [ 3044 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.876814 [ 3045 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:39.925421 [ 3041 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.032165 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.214113 [ 3047 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.549557 [ 3069 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.607591 [ 16551 ] {203a7649-bbfc-44ca-ac2b-6925855f1b90} Context: Server has databases (for example `dict_db_01224`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.10.15 20:32:40.639469 [ 3066 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.744603 [ 3059 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.810500 [ 3065 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.880484 [ 3063 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:40.929200 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.035605 [ 3061 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.217252 [ 3058 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.250005 [ 3056 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.553116 [ 3089 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.644240 [ 3094 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.748050 [ 3103 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.813699 [ 3102 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.843424 [ 3449 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3b7b9d5c-f30c-4cec-915e-651025b581f7::202510_1_120_24}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.884087 [ 3099 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:41.932990 [ 3091 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.039042 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.221046 [ 3110 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.556579 [ 3127 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.648208 [ 3114 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.751023 [ 3115 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.817374 [ 3128 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.886524 [ 3124 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:42.936763 [ 3113 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.042091 [ 3120 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.224922 [ 3205 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.559837 [ 3233 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.658792 [ 3227 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.754461 [ 3241 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.820823 [ 3236 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.889411 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:43.940286 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.044931 [ 3245 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.228050 [ 3271 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.644941 [ 3281 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.661856 [ 3261 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.757819 [ 3289 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.825244 [ 3290 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.893445 [ 3285 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:44.943815 [ 3287 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.048538 [ 3286 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.231048 [ 3295 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.648341 [ 3299 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.665246 [ 3314 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.760991 [ 3324 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.829785 [ 3317 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.900377 [ 3293 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:45.946239 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.064617 [ 3331 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.235444 [ 3310 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.249839 [ 16736 ] {46a63e5a-8e46-4d1e-89e1-28b10a7d590d} executeQuery: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36988) (comment: 02785_left_anti_join_bug.sql) (in query: SELECT * FROM (SELECT CAST('104857.5', 'Float32'), corr(NULL, id, id) AS corr_value FROM test_table__fuzz_3 GROUP BY value) AS subquery ANTI LEFT JOIN test_table ON subquery.corr_value = test_table.id 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:917: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294ab6bf 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:32:46.316478 [ 16736 ] {46a63e5a-8e46-4d1e-89e1-28b10a7d590d} TCPHandler: Code: 48. DB::Exception: Can't execute any of specified algorithms for specified strictness/kind and right storage type. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Planner/PlannerJoins.cpp:917: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294ab6bf 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:32:46.651223 [ 2850 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.668128 [ 2835 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.764312 [ 2824 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.832832 [ 2856 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.904387 [ 2842 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:46.949252 [ 2825 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.067316 [ 2836 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.238269 [ 2872 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.242878 [ 4168 ] {a096f030-fc0c-4c7a-8e62-e2d792a19f9c} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (ae1fd19d-5f4e-465e-ac29-289a1b9c8bf8). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36948) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SELECT 'src_' || toString(number), number FROM numbers(5) SETTINGS insert_deduplication_token='UDT';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:32:47.300436 [ 4168 ] {a096f030-fc0c-4c7a-8e62-e2d792a19f9c} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (ae1fd19d-5f4e-465e-ac29-289a1b9c8bf8). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:32:47.654809 [ 2880 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.671768 [ 2844 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.774807 [ 2829 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.836272 [ 2888 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.907453 [ 2889 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:47.952791 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.069510 [ 2900 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.214613 [ 4168 ] {1144e9f1-d828-4e61-aa66-f6dff986ce2d} executeQuery: Code: 630. DB::Exception: Cannot drop or rename test.hits, because some tables depend on it: db_dict.cache_hits. (HAVE_DEPENDENT_OBJECTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48130) (comment: 00140_rename.sql) (in query: RENAME TABLE test.hits TO test.visits_tmp, test.visits TO test.hits, test.visits_tmp TO 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286df89a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cff35 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000286cf282 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000293730a9 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000029370bfa 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:32:48.241944 [ 2887 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.279769 [ 4168 ] {1144e9f1-d828-4e61-aa66-f6dff986ce2d} TCPHandler: Code: 630. DB::Exception: Cannot drop or rename test.hits, because some tables depend on it: db_dict.cache_hits. (HAVE_DEPENDENT_OBJECTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, std::__wrap_iter, char>>(int, FormatStringHelperImpl::type, std::type_identity, std::__wrap_iter, char>>::type>, DB::StorageID const&, fmt::v9::join_view, std::__wrap_iter, char>&&) @ 0x00000000286df89a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:1523: DB::DatabaseCatalog::checkTableCanBeRemovedOrRenamedUnlocked(DB::StorageID const&, bool, bool, bool) const @ 0x00000000286cff35 5. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::removeDependencies(DB::StorageID const&, bool, bool, bool) @ 0x00000000286cf282 6. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::executeToTables(DB::ASTRenameQuery const&, std::vector> const&, std::map>, std::less, std::allocator>>>>&) @ 0x00000000293730a9 7. ./build_docker/./src/Interpreters/InterpreterRenameQuery.cpp:0: DB::InterpreterRenameQuery::execute() @ 0x0000000029370bfa 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:32:48.658645 [ 2905 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.675801 [ 2909 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.778421 [ 2923 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.843740 [ 2930 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.909819 [ 2918 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:48.955625 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:49.071942 [ 2932 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:49.245161 [ 2947 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:49.661383 [ 2951 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:49.678634 [ 2970 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:49.786494 [ 2964 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:49.846543 [ 2953 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:49.920321 [ 2957 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.038105 [ 2961 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.075206 [ 2968 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.248204 [ 2972 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.663753 [ 2986 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.681164 [ 2989 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.792926 [ 2983 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.855364 [ 2993 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:50.923321 [ 2997 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.042073 [ 2990 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.078395 [ 3011 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.120092 [ 4168 ] {4daf8d68-42c5-4a96-9e28-0a74321db820} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48170) (comment: 00158_cache_dictionary_has.sql) (in query: DROP DICTIONARY IF EXISTS db_dict.cache_hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:32:51.132351 [ 4168 ] {4daf8d68-42c5-4a96-9e28-0a74321db820} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:32:51.251215 [ 3005 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.666010 [ 3028 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.684217 [ 3019 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.796229 [ 3032 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.858903 [ 3029 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:51.926467 [ 3026 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.045440 [ 3046 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.082095 [ 3015 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.253907 [ 3025 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.670094 [ 3044 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.687713 [ 3034 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.799091 [ 3047 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.861755 [ 3030 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:52.935635 [ 3060 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:53.049213 [ 3048 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:53.085294 [ 3055 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:53.265896 [ 3078 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:53.673405 [ 3080 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:53.766850 [ 3074 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:53.802351 [ 3084 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:53.864596 [ 3077 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.029416 [ 3088 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.051778 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.087646 [ 3099 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.268817 [ 3106 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.677085 [ 3129 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.770109 [ 3132 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.805830 [ 3135 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:54.868063 [ 3126 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.034280 [ 3140 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.055492 [ 3123 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.090048 [ 3136 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.271600 [ 3139 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.680371 [ 3157 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.772869 [ 3170 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.847520 [ 3167 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:55.870786 [ 3184 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.030199 [ 2764 ] {5cddd487-332f-436c-9e6c-445c6ae0b8bb} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (8af470cc-dc86-4c51-b5f2-e61c1b1ac395). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48138) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SELECT 'src_4', 4 FROM numbers(5) SETTINGS insert_deduplication_token='UDT';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:32:56.039768 [ 3179 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.043740 [ 2764 ] {5cddd487-332f-436c-9e6c-445c6ae0b8bb} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (8af470cc-dc86-4c51-b5f2-e61c1b1ac395). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:32:56.058528 [ 3187 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.111757 [ 3193 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.338167 [ 3204 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.683573 [ 3200 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.777545 [ 3223 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.850592 [ 3224 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:56.875133 [ 3208 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.043128 [ 3237 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.061111 [ 3199 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.116630 [ 3222 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.341691 [ 3227 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.687280 [ 3225 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.782179 [ 3243 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.853710 [ 3254 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:57.878372 [ 3258 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.046914 [ 3270 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.063946 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.122670 [ 3256 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.346284 [ 3274 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.690612 [ 3264 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.786151 [ 3278 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.858098 [ 3285 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:58.881178 [ 3275 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.051602 [ 3298 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.070544 [ 3282 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.125769 [ 3305 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.135592 [ 16551 ] {500caf2e-f992-4435-b471-f3d6f8cda3c5} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36922) (comment: 01224_no_superfluous_dict_reload.sql) (in query: DROP DICTIONARY dict_db_01224.dict;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:32:59.162150 [ 16551 ] {500caf2e-f992-4435-b471-f3d6f8cda3c5} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:32:59.398947 [ 3299 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.693441 [ 3313 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.722599 [ 2764 ] {413a35b5-d2fa-4087-81c1-874592320d9b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56670) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:32:59.731978 [ 2764 ] {413a35b5-d2fa-4087-81c1-874592320d9b} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:32:59.788704 [ 3318 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.860533 [ 3329 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:32:59.886019 [ 3302 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.077155 [ 3259 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.077442 [ 3310 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.129864 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.134302 [ 16872 ] {bbfe5946-9f72-463c-9b02-5bd05fbfbcec} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56658) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 1000, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:00.162366 [ 16872 ] {bbfe5946-9f72-463c-9b02-5bd05fbfbcec} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:00.401336 [ 2839 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.696528 [ 2847 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.793161 [ 2852 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.863300 [ 2845 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:00.905535 [ 2827 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.080263 [ 2831 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.080772 [ 2842 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.133789 [ 2825 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.404265 [ 2863 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.704640 [ 2843 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.738288 [ 12800 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:57662, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aea84aa 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aef85d2 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1974cb 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d184d40 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.796265 [ 2872 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.866285 [ 2841 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:01.931615 [ 2871 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.084393 [ 2861 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.084883 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.137024 [ 2881 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.406916 [ 2883 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.707310 [ 2900 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.799609 [ 2890 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.872434 [ 2904 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:02.934601 [ 2897 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.087699 [ 2905 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.088660 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.140491 [ 2923 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.160591 [ 16872 ] {4d218bcf-97e9-4942-bad4-9d310da54e7a} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56712) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:03.165180 [ 16872 ] {4d218bcf-97e9-4942-bad4-9d310da54e7a} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:03.409949 [ 2913 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.710259 [ 2943 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.802789 [ 2947 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.875308 [ 2926 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:03.937757 [ 2946 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.091499 [ 2940 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.092376 [ 2945 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.143366 [ 2949 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.471400 [ 2973 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.714101 [ 2976 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.805759 [ 2966 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.878291 [ 2950 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:04.940179 [ 2984 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.094739 [ 2917 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.146472 [ 2967 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.098156 [ 2963 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.474099 [ 2979 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.717783 [ 2997 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.809464 [ 3002 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.881406 [ 2990 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:05.944474 [ 3005 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.103973 [ 3007 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.149326 [ 3006 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.158371 [ 3010 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.477133 [ 3020 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.721038 [ 3012 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.812912 [ 3016 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.884138 [ 3021 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:06.947475 [ 3039 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.154270 [ 3045 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.161830 [ 3057 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.163299 [ 3034 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.292247 [ 3443 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_199_249_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.481331 [ 3042 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.724157 [ 3069 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.817034 [ 3063 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.887628 [ 3081 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:07.990871 [ 3073 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.195677 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.196117 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.197453 [ 3094 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.483881 [ 3099 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.727811 [ 3108 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.820463 [ 3079 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.891417 [ 3100 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:08.998099 [ 3114 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:09.200014 [ 3115 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:09.201208 [ 3117 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:09.202691 [ 3104 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:09.486901 [ 3137 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:09.493499 [ 2764 ] {8cfb453f-2898-4f57-9fcc-f7f54e085b44} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56688) (comment: 02735_parquet_encoder.sql) (in query: select (select sum(cityHash64(*)) from nullables_02735) - (select sum(cityHash64(*)) from file(nullables_02735.parquet));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002837b3e0 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836ba2f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:33:09.498458 [ 2764 ] {8cfb453f-2898-4f57-9fcc-f7f54e085b44} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002837b3e0 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836ba2f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:33:09.731740 [ 3148 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:09.823321 [ 3139 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:09.900083 [ 3158 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.001980 [ 3141 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.207501 [ 3154 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.209666 [ 3168 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.217543 [ 3170 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.489392 [ 3188 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.739499 [ 3176 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.826904 [ 3205 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.903109 [ 3207 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:10.954875 [ 16871 ] {2fb0f689-c371-499b-9422-359454dc80ba} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (fcfa9b68-94e3-4f3f-8bed-4fb82c9f2287). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:56752) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SELECT 'src_' || toString(number), number FROM numbers(5) SETTINGS insert_deduplication_token='UDT';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:33:10.975248 [ 16871 ] {2fb0f689-c371-499b-9422-359454dc80ba} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (fcfa9b68-94e3-4f3f-8bed-4fb82c9f2287). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:33:11.005068 [ 3196 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:11.219987 [ 3229 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:11.220892 [ 3233 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:11.221333 [ 3237 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:11.492661 [ 3240 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:11.785737 [ 3214 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:11.832766 [ 3241 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:11.906657 [ 3213 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.008420 [ 3245 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.030768 [ 16846 ] {2e626152-a425-4726-97ea-637ba0f5d230} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53630) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9b35 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 2025.10.15 20:33:12.052081 [ 16846 ] {2e626152-a425-4726-97ea-637ba0f5d230} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=3): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9b35 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 2025.10.15 20:33:12.150000 [ 16736 ] {dd8b4fe1-b15f-4251-bf1c-4aef04c4e89b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53586) (comment: 00177_memory_bound_merging.sh) (in query: SELECT COUNT() > 0 FROM system.text_log WHERE query_id IN (SELECT query_id FROM system.query_log WHERE query_id != 'query_id_memory_bound_merging_835124709' AND initial_query_id = 'query_id_memory_bound_merging_835124709' AND event_date >= yesterday()) AND event_date >= yesterday() AND message ILIKE '%Reading%ranges in order%'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:33:12.167178 [ 16736 ] {dd8b4fe1-b15f-4251-bf1c-4aef04c4e89b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:33:12.223687 [ 3239 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.224147 [ 3253 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.225137 [ 3265 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.495579 [ 3250 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.789355 [ 3273 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.836335 [ 3272 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:12.909732 [ 3269 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.011448 [ 3264 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.295574 [ 3285 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.295812 [ 3275 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.295779 [ 3294 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.499060 [ 3295 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.775039 [ 16736 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f837f2 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1b228d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1982c2 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d185b41 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:33:13.804354 [ 3308 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.839588 [ 3284 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:13.912684 [ 3307 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.014379 [ 3312 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.299169 [ 3304 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.299782 [ 3317 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.300435 [ 3293 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.502167 [ 3320 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.808163 [ 3326 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.847315 [ 2832 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:14.916534 [ 3330 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.017508 [ 2851 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.068339 [ 16846 ] {f6312cb4-042d-4e74-9e72-eeee1be15545} executeQuery: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53700) (comment: 00063_loyalty_joins.sql) (in query: SELECT loyalty, count() FROM test.hits ANY LEFT JOIN ( SELECT UserID, sum(SearchEngineID = 2) AS yandex, sum(SearchEngineID = 3) AS google, toInt8(if(yandex > google, yandex / (yandex + google), -google / (yandex + google)) * 10) AS loyalty FROM test.hits WHERE (SearchEngineID = 2) OR (SearchEngineID = 3) GROUP BY UserID HAVING (yandex + google) > 10 ) USING UserID GROUP BY loyalty ORDER BY loyalty ASC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000002da15e54 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:445: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000002d9ff7e5 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000002da0006d 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000002da1437c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000278419be 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002dde5a01 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:33:15.078601 [ 16846 ] {f6312cb4-042d-4e74-9e72-eeee1be15545} TCPHandler: Code: 48. DB::Exception: MergeJoinAlgorithm is not implemented for strictness RightAny. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, DB::JoinStrictness&) @ 0x000000002da15e54 4. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:445: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(DB::JoinKind, DB::JoinStrictness, DB::TableJoin::JoinOnClause const&, std::vector> const&, unsigned long) @ 0x000000002d9ff7e5 5. ./build_docker/./src/Processors/Transforms/MergeJoinTransform.cpp:0: DB::MergeJoinAlgorithm::MergeJoinAlgorithm(std::shared_ptr, std::vector> const&, unsigned long) @ 0x000000002da0006d 6. ./src/Processors/Merges/IMergingTransform.h:166: DB::MergeJoinTransform::MergeJoinTransform(std::shared_ptr, std::vector> const&, DB::Block const&, unsigned long, unsigned long) @ 0x000000002da1437c 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::QueryPipelineBuilder::joinPipelinesYShaped(std::unique_ptr>, std::unique_ptr>, std::shared_ptr, DB::Block const&, unsigned long, std::vector, std::allocator>>*) @ 0x00000000278419be 8. ./build_docker/./src/Processors/QueryPlan/JoinStep.cpp:60: DB::JoinStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002dde5a01 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:33:15.302651 [ 2828 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.305513 [ 2823 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.305703 [ 2822 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.372596 [ 17624 ] {420c4aa6-9808-4b56-bbc4-1a1d3adb8202} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53632) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:15.398745 [ 17624 ] {420c4aa6-9808-4b56-bbc4-1a1d3adb8202} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:15.505240 [ 2847 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.630868 [ 16881 ] {10a04122-6c5d-48ee-be96-f438a0d03536} executeQuery: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53606) (comment: 02769_compare_functions_nan.sql) (in query: CREATE TABLE test_table (`id` Float32, `value` Float32) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 5148, min_bytes_for_wide_part = 111136450, ratio_of_defaults_for_sparse_serialization = 0.6314275860786438, replace_long_file_name_to_hash = false, max_file_name_length = 75, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 8733284, compact_parts_max_granules_to_buffer = 195, compact_parts_merge_max_bytes_to_prefetch_part = 24680392, merge_max_block_size = 22181, old_parts_lifetime = 108., 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 = 3243236857, index_granularity_bytes = 15867094, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 69572, primary_key_compress_block_size = 24379), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:15.640389 [ 16881 ] {10a04122-6c5d-48ee-be96-f438a0d03536} TCPHandler: Code: 57. DB::Exception: Table test_3.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:15.814567 [ 3325 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.854899 [ 2845 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:15.919683 [ 2827 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.020613 [ 2856 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.305487 [ 2867 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.308548 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.309150 [ 2869 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.508283 [ 2862 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.559362 [ 16736 ] {5265d162-5424-4349-9b36-29fa6a69eff5} executeQuery: Code: 60. DB::Exception: Table test_15.t_json_13 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53690) (comment: 01825_type_json_13.sh) (in query: INSERT INTO t_json_13 FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd545e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b2c2b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bed37 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000293520f6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000029361609 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:33:16.583413 [ 16736 ] {5265d162-5424-4349-9b36-29fa6a69eff5} TCPHandler: Code: 60. DB::Exception: Table test_15.t_json_13 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd545e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b2c2b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bed37 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000293520f6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000029361609 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:33:16.820445 [ 2855 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.858344 [ 2868 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:16.925223 [ 2872 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.023578 [ 2859 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.229078 [ 16846 ] {6ac75686-99c0-42ba-8abb-b846ba8c6f9b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38598) (comment: 00078_group_by_arrays.sql) (in query: SELECT ParsedParams.Key1 AS k1, GeneralInterests AS k2, count() AS c FROM test.hits WHERE notEmpty(k1) AND notEmpty(k2) GROUP BY k1, k2 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:17.235293 [ 16846 ] {6ac75686-99c0-42ba-8abb-b846ba8c6f9b} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:17.309862 [ 2882 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.311250 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.312372 [ 2902 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.511464 [ 2907 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.676089 [ 16736 ] {f15c322a-3282-4dae-9a6a-e02aa3599dbc} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_13. (UNKNOWN_TABLE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38650) (comment: 01825_type_json_13.sh) (in query: SELECT DISTINCT toTypeName(obj) FROM t_json_13;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:33:17.702603 [ 16736 ] {f15c322a-3282-4dae-9a6a-e02aa3599dbc} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT DISTINCT toTypeName(obj) FROM t_json_13. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:33:17.823949 [ 2901 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.861435 [ 2899 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:17.929146 [ 2890 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.028100 [ 2893 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.164168 [ 16881 ] {167276b2-a991-4810-8ecf-9383e5b99451} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38608) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:18.191399 [ 16881 ] {167276b2-a991-4810-8ecf-9383e5b99451} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:18.312976 [ 2930 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.314077 [ 2919 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.314940 [ 2918 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.514604 [ 2913 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.649405 [ 16846 ] {87ff77e3-0a4c-4712-9767-f5083599f6d5} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj FROM t_json_13 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38678) (comment: 01825_type_json_13.sh) (in query: SELECT obj FROM t_json_13 ORDER BY obj.id FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:33:18.678396 [ 16846 ] {87ff77e3-0a4c-4712-9767-f5083599f6d5} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj FROM t_json_13 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:33:18.827618 [ 2947 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.864686 [ 2916 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:18.931960 [ 2934 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.031421 [ 2922 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.316221 [ 2948 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.321221 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.321841 [ 2941 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.517674 [ 2952 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.678824 [ 16846 ] {853ff83a-462e-4b95-9ae1-53b1b5a616cb} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj.key_1.key_2.key_3.key_8, obj.key_1.key_2.key_3.key_4.key_5, obj.key_1.key_2.key_3.key_4.key_6, obj.key_1.key_2.key_3.key_4.key_7 FROM t_json_13 ORDER BY obj.id ASC. (UNKNOWN_TABLE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38694) (comment: 01825_type_json_13.sh) (in query: SELECT obj.key_1.key_2.key_3.key_8, obj.key_1.key_2.key_3.key_4.key_5, obj.key_1.key_2.key_3.key_4.key_6, obj.key_1.key_2.key_3.key_4.key_7 FROM t_json_13 ORDER BY obj.id), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:33:19.686388 [ 16846 ] {853ff83a-462e-4b95-9ae1-53b1b5a616cb} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_13' in scope SELECT obj.key_1.key_2.key_3.key_8, obj.key_1.key_2.key_3.key_4.key_5, obj.key_1.key_2.key_3.key_4.key_6, obj.key_1.key_2.key_3.key_4.key_7 FROM t_json_13 ORDER BY obj.id ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bc030 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e658 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 21. asan_thread_start(void*) @ 0x000000000aa45059 22. ? @ 0x00007f2f94fabac3 23. ? @ 0x00007f2f9503d850 2025.10.15 20:33:19.833351 [ 2958 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.868676 [ 2966 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:19.935440 [ 2959 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.034337 [ 2917 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.075988 [ 17625 ] {e9d15264-af7c-4978-a49a-4dfb3acc2df4} executeQuery: Code: 57. DB::Exception: Table test_3.dt already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38636) (comment: 00745_compile_scalar_subquery.sql) (in query: CREATE TABLE dt (`tkey` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 40430, min_bytes_for_wide_part = 548452051, 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 = 0, compact_parts_max_bytes_to_buffer = 268112471, compact_parts_max_granules_to_buffer = 173, compact_parts_merge_max_bytes_to_prefetch_part = 29692157, merge_max_block_size = 4863, old_parts_lifetime = 362., prefer_fetch_merged_part_size_threshold = 2304714226, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9277966385, index_granularity_bytes = 1543911, concurrent_part_removal_threshold = 17, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 86245, primary_key_compress_block_size = 19901), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:20.091650 [ 17625 ] {e9d15264-af7c-4978-a49a-4dfb3acc2df4} TCPHandler: Code: 57. DB::Exception: Table test_3.dt already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:20.319565 [ 2977 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.328845 [ 2994 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.329595 [ 2985 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.527127 [ 2986 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.820505 [ 16736 ] {40f6c14d-5d12-42db-b97a-dfc333fecc89} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38686) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:20.839245 [ 2990 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.849384 [ 16736 ] {40f6c14d-5d12-42db-b97a-dfc333fecc89} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:20.872944 [ 2998 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:20.938278 [ 3004 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.037322 [ 3013 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.322830 [ 3006 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.332404 [ 3010 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.334275 [ 3018 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.530249 [ 3029 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.849000 [ 3033 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.876652 [ 3015 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:21.941028 [ 3012 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.040369 [ 3016 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.147888 [ 16881 ] {3367564a-2d38-419b-a009-5ca68e7d4bbb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38728) (comment: 00054_merge_tree_partitions.sql) (in query: INSERT INTO test.partitions SELECT EventDate + UserID % 365 AS EventDate, CounterID FROM test.hits WHERE CounterID = 1704509;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:33:22.190268 [ 16881 ] {3367564a-2d38-419b-a009-5ca68e7d4bbb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:33:22.325927 [ 3057 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.336168 [ 3052 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.337510 [ 3047 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.542516 [ 3055 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.753009 [ 16846 ] {af63d301-d9a9-4c07-8dd7-3ee0a29c9d49} executeQuery: Code: 60. DB::Exception: Table test_15.t_json_13 does not exist. (UNKNOWN_TABLE) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38706) (comment: 01825_type_json_13.sh) (in query: DROP TABLE t_json_13;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd545e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b2c2b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bf24c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f53f1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:33:22.763428 [ 16846 ] {af63d301-d9a9-4c07-8dd7-3ee0a29c9d49} TCPHandler: Code: 60. DB::Exception: Table test_15.t_json_13 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd545e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b2c2b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:969: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bf24c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f53f1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 2025.10.15 20:33:22.852427 [ 3068 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.882511 [ 3054 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:22.945783 [ 3085 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.043284 [ 3069 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.329751 [ 3073 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.339351 [ 3083 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.340689 [ 3080 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.383831 [ 17624 ] {cbae3ddc-2b0b-4982-83e6-df738314d0b0} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38732) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:23.404001 [ 17624 ] {cbae3ddc-2b0b-4982-83e6-df738314d0b0} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:23.547447 [ 3095 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.855725 [ 3101 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.886642 [ 3075 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:23.948851 [ 3087 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.046419 [ 3099 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.336415 [ 3108 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.342720 [ 3110 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.343698 [ 3106 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.550020 [ 3105 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.858563 [ 3113 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.890708 [ 3124 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:24.951256 [ 3126 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.049121 [ 3144 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.343510 [ 3152 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.346322 [ 3153 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.346425 [ 3162 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.535248 [ 16871 ] {f94edc22-8193-445d-a31e-225f74cbfc18} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38788) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:25.542872 [ 16871 ] {f94edc22-8193-445d-a31e-225f74cbfc18} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:25.559487 [ 3142 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.862241 [ 3146 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.893555 [ 3169 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:25.983736 [ 3177 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.094019 [ 3188 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.153407 [ 3183 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.348195 [ 3190 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.350071 [ 3193 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.354577 [ 3194 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.654376 [ 3186 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.865337 [ 3215 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.864928 [ 12800 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.957726 [ 3224 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:26.986868 [ 3202 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.097372 [ 3231 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.353745 [ 3222 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.354854 [ 3240 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.357837 [ 3242 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.658123 [ 3244 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.869579 [ 3245 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.960733 [ 3254 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:27.990725 [ 3265 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:28.140650 [ 3260 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:28.209847 [ 16881 ] {e7ddd2a4-0bee-405f-8752-f0635d349189} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52256) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:28.222381 [ 2764 ] {c7d88bd8-1e61-4c20-aa93-98ca6b617c42} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38786) (comment: 00165_jit_aggregate_functions.sql) (in query: WITH (WatchID % 2 == 0) AS predicate SELECT minIf(WatchID, predicate) as min_watch_id, maxIf(WatchID, predicate), sumIf(WatchID, predicate), avgIf(WatchID, predicate), avgWeightedIf(WatchID, CounterID, predicate), countIf(WatchID, predicate), groupBitOrIf(WatchID, predicate), groupBitAndIf(WatchID, predicate), groupBitXorIf(WatchID, predicate) FROM test.hits ORDER BY min_watch_id DESC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:28.233966 [ 16881 ] {e7ddd2a4-0bee-405f-8752-f0635d349189} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:28.299975 [ 2764 ] {c7d88bd8-1e61-4c20-aa93-98ca6b617c42} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:28.359257 [ 3267 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:28.359536 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:28.370304 [ 3279 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:28.617987 [ 3682 ] {61c8abd5-2f41-45e3-9408-57f2c03e90c3} test_15.tbl (28d21208-942b-475d-8cb1-8980fe61a217): Part /var/lib/clickhouse/store/28d/28d21208-942b-475d-8cb1-8980fe61a217/tmp_restore_all_2_2_0-1ce777b8-a731-40f0-bcfd-2e11dbf83937/ is broken and needs manual correction 2025.10.15 20:33:28.622717 [ 3682 ] {61c8abd5-2f41-45e3-9408-57f2c03e90c3} test_15.tbl (28d21208-942b-475d-8cb1-8980fe61a217): Failed to restore part all_2_2_0 because it's broken. You can skip broken parts while restoring by setting 'restore_broken_parts_as_detached = true' 2025.10.15 20:33:28.661015 [ 3264 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:28.760133 [ 17624 ] {61c8abd5-2f41-45e3-9408-57f2c03e90c3} BackupsWorker: Failed to restore from backup Disk('backups', 'test_15/with_broken_part.zip'): Code: 107. DB::Exception: store/28d/28d21208-942b-475d-8cb1-8980fe61a217/tmp_restore_all_2_2_0-1ce777b8-a731-40f0-bcfd-2e11dbf83937/data.bin doesn't exist: columns: columns format version: 1 1 columns: `x` Int64 , getMarkSizeInBytes: 24, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 0, fixed_index_granularity: 8192], index_granularity: [initialized: true, marks_rows_partial_sums: [1, 1]], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (48 bytes), count.txt (1 bytes), serialization.json (85 bytes), checksums.txt (210 bytes), default_compression_codec.txt (10 bytes), columns.txt (47 bytes), metadata_version.txt (1 bytes): while restoring part all_2_2_0 of table test_15.tbl (28d21208-942b-475d-8cb1-8980fe61a217). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000002c5bf6f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:69: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000002c5c2525 5. ./contrib/llvm-project/libcxx/include/__tree:189: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000002c308a11 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2211: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000002c2eac9b 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:743: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000002c2e0c47 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5741: DB::MergeTreeData::loadPartRestoredFromBackup(String const&, std::shared_ptr const&, String const&, bool) const @ 0x000000002c4f3c75 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5718: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x000000002c4f202a 10. ./contrib/llvm-project/libcxx/include/string:1499: void std::__function::__policy_invoker::__call_impl, 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002c557bd7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x00000000271450d4 12. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:28.768542 [ 17624 ] {61c8abd5-2f41-45e3-9408-57f2c03e90c3} executeQuery: Code: 107. DB::Exception: store/28d/28d21208-942b-475d-8cb1-8980fe61a217/tmp_restore_all_2_2_0-1ce777b8-a731-40f0-bcfd-2e11dbf83937/data.bin doesn't exist: columns: columns format version: 1 1 columns: `x` Int64 , getMarkSizeInBytes: 24, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 0, fixed_index_granularity: 8192], index_granularity: [initialized: true, marks_rows_partial_sums: [1, 1]], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (48 bytes), count.txt (1 bytes), serialization.json (85 bytes), checksums.txt (210 bytes), default_compression_codec.txt (10 bytes), columns.txt (47 bytes), metadata_version.txt (1 bytes): while restoring part all_2_2_0 of table test_15.tbl (28d21208-942b-475d-8cb1-8980fe61a217). (FILE_DOESNT_EXIST) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52316) (comment: 02864_restore_table_with_broken_part.sh) (in query: RESTORE TABLE default.tbl AS tbl FROM Disk('backups', 'test_15/with_broken_part.zip')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000002c5bf6f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:69: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000002c5c2525 5. ./contrib/llvm-project/libcxx/include/__tree:189: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000002c308a11 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2211: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000002c2eac9b 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:743: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000002c2e0c47 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5741: DB::MergeTreeData::loadPartRestoredFromBackup(String const&, std::shared_ptr const&, String const&, bool) const @ 0x000000002c4f3c75 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5718: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x000000002c4f202a 10. ./contrib/llvm-project/libcxx/include/string:1499: void std::__function::__policy_invoker::__call_impl, 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002c557bd7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x00000000271450d4 12. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:33:28.786372 [ 17624 ] {61c8abd5-2f41-45e3-9408-57f2c03e90c3} TCPHandler: Code: 107. DB::Exception: store/28d/28d21208-942b-475d-8cb1-8980fe61a217/tmp_restore_all_2_2_0-1ce777b8-a731-40f0-bcfd-2e11dbf83937/data.bin doesn't exist: columns: columns format version: 1 1 columns: `x` Int64 , getMarkSizeInBytes: 24, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 0, fixed_index_granularity: 8192], index_granularity: [initialized: true, marks_rows_partial_sums: [1, 1]], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (48 bytes), count.txt (1 bytes), serialization.json (85 bytes), checksums.txt (210 bytes), default_compression_codec.txt (10 bytes), columns.txt (47 bytes), metadata_version.txt (1 bytes): while restoring part all_2_2_0 of table test_15.tbl (28d21208-942b-475d-8cb1-8980fe61a217). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000002c5bf6f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:69: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000002c5c2525 5. ./contrib/llvm-project/libcxx/include/__tree:189: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000002c308a11 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2211: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000002c2eac9b 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:743: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000002c2e0c47 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5741: DB::MergeTreeData::loadPartRestoredFromBackup(String const&, std::shared_ptr const&, String const&, bool) const @ 0x000000002c4f3c75 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5718: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x000000002c4f202a 10. ./contrib/llvm-project/libcxx/include/string:1499: void std::__function::__policy_invoker::__call_impl, 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002c557bd7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x00000000271450d4 12. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:33:28.874428 [ 3271 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.027349 [ 3286 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.029053 [ 3283 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.143894 [ 3305 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.362969 [ 3306 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.363603 [ 3261 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.373584 [ 3321 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.668129 [ 3320 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:29.894069 [ 2832 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.029831 [ 2839 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.031595 [ 2851 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.168099 [ 3334 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.268313 [ 2764 ] {439cc07c-5f1b-4d03-9dba-3dcaeecd782f} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52340) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:30.300174 [ 2764 ] {439cc07c-5f1b-4d03-9dba-3dcaeecd782f} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:30.366109 [ 2854 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.366959 [ 2847 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.384777 [ 2830 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.671521 [ 2856 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:30.897499 [ 2853 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.033316 [ 2846 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.034602 [ 2863 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.171280 [ 2858 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.319440 [ 5068 ] {72acc647-071e-4641-b98c-1f3876fa4dd5} test_15.tbl (d4c23ebb-dcdf-4b36-9f68-8f08e19e43be): Part /var/lib/clickhouse/store/d4c/d4c23ebb-dcdf-4b36-9f68-8f08e19e43be/tmp_restore_all_2_2_0-d1dc5ee9-a14d-4288-b7a3-451e97e01c0b/ is broken and needs manual correction 2025.10.15 20:33:31.326267 [ 5068 ] {72acc647-071e-4641-b98c-1f3876fa4dd5} test_15.tbl (d4c23ebb-dcdf-4b36-9f68-8f08e19e43be): Part all_2_2_0 will be restored as detached because it's broken. You need to resolve this manually: Code: 107. DB::Exception: store/d4c/d4c23ebb-dcdf-4b36-9f68-8f08e19e43be/tmp_restore_all_2_2_0-d1dc5ee9-a14d-4288-b7a3-451e97e01c0b/data.bin doesn't exist: columns: columns format version: 1 1 columns: `x` Int64 , getMarkSizeInBytes: 24, getMarksCount: 2, index_granularity_info: [mark_type: [adaptive: true, compressed: true, part_type: Compact], index_granularity_bytes: 0, fixed_index_granularity: 8192], index_granularity: [initialized: true, marks_rows_partial_sums: [1, 1]], part_state: [state: Temporary, is_unexpected_local_part: false, is_frozen: false, is_duplicate: false]: Part contains files: data.cmrk3 (48 bytes), count.txt (1 bytes), serialization.json (85 bytes), checksums.txt (210 bytes), default_compression_codec.txt (10 bytes), columns.txt (47 bytes), metadata_version.txt (1 bytes). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type>, std::__fs::filesystem::path&&) @ 0x000000002c5bf6f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartChecksum.cpp:69: DB::MergeTreeDataPartChecksum::checkSize(DB::IDataPartStorage const&, String const&) const @ 0x000000002c5c2525 5. ./contrib/llvm-project/libcxx/include/__tree:189: DB::IMergeTreeDataPart::checkConsistencyBase() const @ 0x000000002c308a11 6. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:2211: DB::IMergeTreeDataPart::checkConsistency(bool) const @ 0x000000002c2eac9b 7. ./build_docker/./src/Storages/MergeTree/IMergeTreeDataPart.cpp:743: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000002c2e0c47 8. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5741: DB::MergeTreeData::loadPartRestoredFromBackup(String const&, std::shared_ptr const&, String const&, bool) const @ 0x000000002c4f3c75 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5718: DB::MergeTreeData::restorePartFromBackup(std::shared_ptr, DB::MergeTreePartInfo const&, String const&, bool) const @ 0x000000002c4f202a 10. ./contrib/llvm-project/libcxx/include/string:1499: void std::__function::__policy_invoker::__call_impl, 7ul, std::allocator>>> const&)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x000000002c557bd7 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x00000000271450d4 12. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.370371 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.370686 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.391517 [ 2872 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.678130 [ 2874 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:31.901067 [ 2866 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.036402 [ 2889 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.037556 [ 2883 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.181566 [ 2902 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.374315 [ 2901 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.383765 [ 2895 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.403377 [ 2899 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.449927 [ 3444 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {d4c23ebb-dcdf-4b36-9f68-8f08e19e43be::all_1_2_1}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.685253 [ 2920 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:32.905011 [ 2918 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.040839 [ 2910 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.040823 [ 2904 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.184708 [ 2921 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.378626 [ 2937 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.386792 [ 2926 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.445258 [ 2946 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.688357 [ 2942 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:33.796017 [ 12798 ] {f84034bc-2785-40c7-a06c-d841dde3af55} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52424) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:33:33.898464 [ 12798 ] {f84034bc-2785-40c7-a06c-d841dde3af55} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:33:33.908416 [ 2956 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.044692 [ 2944 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.045080 [ 2973 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.189806 [ 2950 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.381120 [ 2961 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.389317 [ 2917 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.449302 [ 2986 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.691847 [ 2996 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:34.762427 [ 16872 ] {8f0dbdc9-11cb-41aa-811f-bd478ab59933} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52436) (comment: 02922_deduplication_with_zero_copy.sh) (in query: insert into r1 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699edf3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699e8f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1d202 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026aee901 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::preFinalize() @ 0x0000000026aed91e 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8edcee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000002cb25aa5 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 19. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a8b3 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:33:34.771805 [ 16872 ] {8f0dbdc9-11cb-41aa-811f-bd478ab59933} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699edf3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699e8f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1d202 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026aee901 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::preFinalize() @ 0x0000000026aed91e 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8edcee 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000002cb25aa5 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 19. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a8b3 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:33:34.912004 [ 3011 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.048402 [ 2999 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.049252 [ 3024 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.193253 [ 3022 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.388328 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.393160 [ 3020 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.454379 [ 3033 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.696738 [ 3031 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:35.917085 [ 3062 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.051628 [ 3042 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.056376 [ 3048 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.197930 [ 3064 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.391887 [ 3072 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.397882 [ 3090 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.460482 [ 3095 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.700047 [ 3098 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:36.920679 [ 3101 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.054322 [ 3099 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.059642 [ 3091 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.201822 [ 3116 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.395943 [ 3114 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.402318 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.465933 [ 3093 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.703308 [ 3124 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:37.925539 [ 3144 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.056901 [ 3135 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.062235 [ 3133 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.207498 [ 3139 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.386644 [ 12798 ] {af6fce6e-33d2-40d0-a9c6-73975702a35d} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52448) (comment: 00061_storage_buffer.sql) (in query: DROP TABLE test.hits_buffer;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:33:38.396063 [ 12798 ] {af6fce6e-33d2-40d0-a9c6-73975702a35d} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:33:38.399185 [ 3157 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.405523 [ 3142 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.468882 [ 3151 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.707924 [ 3182 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:38.877428 [ 17626 ] {219f326c-b9dd-4661-8cdb-dd7bfd84e294} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (6e7ff507-375b-4e52-9c67-66cc8835d707). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52372) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SELECT 'src_' || toString(number), number FROM numbers(5) SETTINGS insert_deduplication_token='UDT';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:33:38.928532 [ 17626 ] {219f326c-b9dd-4661-8cdb-dd7bfd84e294} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (6e7ff507-375b-4e52-9c67-66cc8835d707). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:33:38.929079 [ 3187 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.059489 [ 3181 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.097829 [ 3195 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.210443 [ 3178 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.402410 [ 3207 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.408480 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.471783 [ 3212 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.711820 [ 3221 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:39.932458 [ 3237 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.062247 [ 3208 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.101119 [ 3240 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.217136 [ 3241 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.231763 [ 2764 ] {a653f639-b729-4d8e-be4e-3d8864e36611} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49728) (comment: 02922_deduplication_with_zero_copy.sh) (in query: insert into r2 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699edf3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699e8f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1d202 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026aee901 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::preFinalize() @ 0x0000000026aed91e 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8ec8f9 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000002cb25aa5 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 19. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a8b3 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:33:40.304457 [ 2764 ] {a653f639-b729-4d8e-be4e-3d8864e36611} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699edf3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699e8f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1d202 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026aee901 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::preFinalize() @ 0x0000000026aed91e 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8ec8f9 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000002cb25aa5 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 19. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a8b3 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:33:40.404774 [ 3254 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.411059 [ 3239 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.474140 [ 3270 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.719444 [ 3256 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:40.936645 [ 3272 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.065208 [ 3264 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.106647 [ 3289 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.220047 [ 3294 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.408077 [ 3291 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.413706 [ 3300 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.477235 [ 3303 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.722815 [ 3282 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:41.940139 [ 3321 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.069130 [ 3293 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.109969 [ 3313 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.223464 [ 3320 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.413817 [ 3326 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.416724 [ 3310 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.480953 [ 3330 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.731564 [ 2828 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:42.770558 [ 2764 ] {55d063dd-8690-4d71-9300-36c933832ec2} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49780) (comment: 00157_cache_dictionary.sql) (in query: DROP DICTIONARY IF EXISTS db_dict.cache_hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:33:42.795216 [ 2764 ] {55d063dd-8690-4d71-9300-36c933832ec2} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:33:42.943231 [ 2847 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.074261 [ 2852 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.115110 [ 2845 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.227297 [ 2827 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.418162 [ 2860 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.419516 [ 2837 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.488486 [ 2833 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.735194 [ 2857 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:43.946443 [ 2870 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.076970 [ 2889 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.119112 [ 2900 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.257665 [ 2901 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.424038 [ 2903 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.424302 [ 2897 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.491755 [ 2911 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.738606 [ 2918 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:44.951816 [ 2943 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.072203 [ 12798 ] {fee8ea5b-8dac-453d-a08d-66f8b61c4860} executeQuery: Code: 57. DB::Exception: Table test_1.table_when_b_even_and_joined already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49756) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_when_b_even_and_joined (`a_src` String, `a_join` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_when_b_even_and_joined', '1') ORDER BY (a_src, a_join, b) SETTINGS replicated_deduplication_window = 1000, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:45.079956 [ 2937 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.082434 [ 12798 ] {fee8ea5b-8dac-453d-a08d-66f8b61c4860} TCPHandler: Code: 57. DB::Exception: Table test_1.table_when_b_even_and_joined already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:45.130985 [ 2922 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.261706 [ 2948 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.427165 [ 2952 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.427913 [ 2951 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.494854 [ 2953 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.655709 [ 16960 ] {8fe9c3cf-8b2e-4bda-9ff9-2cd8c569c1d2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=739). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56714) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:45.662395 [ 16960 ] {8fe9c3cf-8b2e-4bda-9ff9-2cd8c569c1d2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=739). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:45.742561 [ 2964 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.771645 [ 4168 ] {7138350b-1dd1-4537-8592-d78c2de0ebcc} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=739). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49854) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfa817e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:33:45.778288 [ 16881 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:47938, local: [::ffff:127.0.0.3]: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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0b80a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0b8be4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf150f6 6. DB::ReadBuffer::next() @ 0x000000000b52aaeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d185ab3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:45.800499 [ 4168 ] {7138350b-1dd1-4537-8592-d78c2de0ebcc} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.4:9000. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=739). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 : 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebb7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cef776a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf0830e 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfa817e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278aedb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278ae3c4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278abd14 2025.10.15 20:33:45.955104 [ 2962 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.087613 [ 2959 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.135894 [ 2982 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.265839 [ 2996 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.433542 [ 3011 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.433927 [ 3004 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.498941 [ 3007 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.746202 [ 3014 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:46.957948 [ 3022 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.090433 [ 3038 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.139219 [ 3031 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.353992 [ 3046 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.465034 [ 3050 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.471879 [ 3050 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.501939 [ 3030 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.749361 [ 3085 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:47.960745 [ 3071 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.002757 [ 16736 ] {f5c7e98e-e4fa-47e6-8ca7-56c4e571b445} 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.10521.altinitytest (altinity build)) (from [::1]:48432) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: INSERT INTO table_for_join_with SELECT 'joined_' || toString(number), 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d356ec7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:48.030502 [ 16736 ] {f5c7e98e-e4fa-47e6-8ca7-56c4e571b445} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d356ec7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:48.093532 [ 3072 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.146443 [ 3090 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.357303 [ 3082 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.474276 [ 3094 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.475318 [ 3101 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.515818 [ 3102 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.760565 [ 3087 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:48.845939 [ 16960 ] {fe2c60d8-3d29-468f-ac4c-c8c503ef6530} 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.10521.altinitytest (altinity build)) (from [::1]:48452) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:48.881767 [ 16960 ] {fe2c60d8-3d29-468f-ac4c-c8c503ef6530} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:33:48.963978 [ 3100 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.098870 [ 16736 ] {fa93d0a2-acb7-4c72-8ee6-ce1b3478f828} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:53730). (NETWORK_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53730) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:33:49.100236 [ 3115 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.111194 [ 16736 ] {fa93d0a2-acb7-4c72-8ee6-ce1b3478f828} 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]:53730). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1ba6cb 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d19e639 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1873e2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.114991 [ 16736 ] {fa93d0a2-acb7-4c72-8ee6-ce1b3478f828} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:53730). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf1a6f7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProfileInfo(DB::ProfileInfo const&) @ 0x000000002d1a7517 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19c0e7 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:33:49.126057 [ 16736 ] {fa93d0a2-acb7-4c72-8ee6-ce1b3478f828} TCPHandler: Client has gone away. 2025.10.15 20:33:49.149780 [ 3117 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.410575 [ 3132 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.477862 [ 3144 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.478905 [ 3131 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.521145 [ 3137 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.763817 [ 3125 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.952000 [ 3606 ] {} PushingToViews: Cannot push to the storage, ignoring the error: Code: 60. DB::Exception: Table test_15.receiver_02572 does not exist: while pushing to view test_15.push_to_logs_proxy_mv_02572 (ca0f61bb-6860-498c-b13e-5ce6aab9003a). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd545e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b2c2b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bed37 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000293520f6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000029361609 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000002c21cf8a 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x000000002c20ff3d 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000002c20d9b9 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 19. ./build_docker/./src/Interpreters/SystemLog.cpp:525: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000297dbe41 20. ./build_docker/./src/Interpreters/SystemLog.cpp:451: DB::SystemLog::savingThreadFunction() @ 0x00000000297daaaa 21. ./build_docker/./src/Common/SystemLogBase.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001b016248 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:49.967117 [ 3147 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.103951 [ 3157 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.153008 [ 3155 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.414548 [ 3159 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.489332 [ 3185 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.489396 [ 3179 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.524352 [ 3190 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.768141 [ 3206 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:50.972170 [ 3189 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.107063 [ 3205 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.155846 [ 3224 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.417011 [ 3231 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.496309 [ 3237 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.496773 [ 3235 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.527459 [ 3199 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.771477 [ 3214 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:51.976875 [ 3211 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.112988 [ 3254 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.159418 [ 3239 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.420331 [ 3234 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.499687 [ 3243 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.505232 [ 3262 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.530639 [ 3267 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.659838 [ 3606 ] {} PushingToViews: Cannot push to the storage, ignoring the error: Code: 60. DB::Exception: Table test_15.receiver_02572 does not exist: while pushing to view test_15.push_to_logs_proxy_mv_02572 (ca0f61bb-6860-498c-b13e-5ce6aab9003a). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027dd545e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b2c2b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286bed37 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x00000000293520f6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x0000000029361609 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000002c21cf8a 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x000000002c20ff3d 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000002c20d9b9 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 19. ./build_docker/./src/Interpreters/SystemLog.cpp:525: DB::SystemLog::flushImpl(std::vector> const&, unsigned long) @ 0x00000000297dbe41 20. ./build_docker/./src/Interpreters/SystemLog.cpp:451: DB::SystemLog::savingThreadFunction() @ 0x00000000297daaaa 21. ./build_docker/./src/Common/SystemLogBase.cpp:0: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl::startup()::'lambda'()>(DB::SystemLogBase::startup()::'lambda'()&&)::'lambda'()::operator()() @ 0x000000001b016248 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.780345 [ 3269 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:52.981202 [ 3278 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:53.039113 [ 16960 ] {ce8ae950-9bb4-4096-8e23-c3954ff7179c} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48468) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:53.062967 [ 16960 ] {ce8ae950-9bb4-4096-8e23-c3954ff7179c} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:53.116181 [ 3305 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:53.169086 [ 3301 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:53.371751 [ 4168 ] {50d2be77-5ebf-489d-8da0-81afba8c965f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48550) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:33:53.387260 [ 4168 ] {50d2be77-5ebf-489d-8da0-81afba8c965f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:33:53.454758 [ 3307 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:53.502142 [ 3261 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:53.507993 [ 3321 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:53.538170 [ 3312 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:53.784046 [ 3328 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.004260 [ 2832 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.119542 [ 2851 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.172932 [ 2839 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.458736 [ 2830 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.505398 [ 2822 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.511288 [ 2824 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.541955 [ 2856 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:54.688790 [ 16736 ] {36e4d703-14c4-40da-81f3-2eb1b5a281d6} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.027925823 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48560) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:33:54.734172 [ 16736 ] {36e4d703-14c4-40da-81f3-2eb1b5a281d6} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1.027925823 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:33:54.791990 [ 2860 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.007547 [ 2857 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.122664 [ 2848 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.176406 [ 2869 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.408618 [ 4168 ] {ac82b6e3-0c1a-4921-b220-2ce47d82a447} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48566) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:55.434569 [ 4168 ] {ac82b6e3-0c1a-4921-b220-2ce47d82a447} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:55.461627 [ 2873 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.508571 [ 2874 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.514698 [ 2888 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.545226 [ 2866 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:55.797346 [ 2907 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.009964 [ 2886 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.126541 [ 2899 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.179430 [ 2898 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.464555 [ 2930 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.511798 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.517943 [ 2918 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.548467 [ 2892 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:56.652603 [ 17624 ] {6cc098d1-46ae-4a00-b437-ed96635ba684} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50698) (comment: 00162_mmap_compression_none.sql) (in query: INSERT INTO hits_none SELECT Title FROM test.hits 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:33:56.709319 [ 17624 ] {6cc098d1-46ae-4a00-b437-ed96635ba684} TCPHandler: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:33:56.800768 [ 2943 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.011942 [ 2926 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.129557 [ 2940 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.182403 [ 2935 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.467382 [ 2929 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.515101 [ 2954 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.521205 [ 2952 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.552130 [ 2970 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.804820 [ 2965 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:57.962713 [ 16551 ] {06fc6615-544b-4ba9-9e94-0ad3c059daf0} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50722) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:57.999077 [ 16551 ] {06fc6615-544b-4ba9-9e94-0ad3c059daf0} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:33:58.014823 [ 2964 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:58.132478 [ 2960 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:58.188191 [ 2963 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:58.470185 [ 2979 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:58.518434 [ 2974 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:58.524567 [ 2987 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:58.555292 [ 2983 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:58.807808 [ 2997 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.021466 [ 2975 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.136059 [ 2999 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.192140 [ 3024 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.424918 [ 12798 ] {c5a70c3d-395f-499b-8e97-85f7b069698f} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50796) (comment: 01762_deltasumtimestamp_datetime64.sh) (in query: SELECT deltaSumTimestamp(1, now64());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:193: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002224ea3e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839dd27 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 27. asan_thread_start(void*) @ 0x000000000aa45059 28. ? @ 0x00007f2f94fabac3 29. ? @ 0x00007f2f9503d850 2025.10.15 20:33:59.430224 [ 12798 ] {c5a70c3d-395f-499b-8e97-85f7b069698f} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionDeltaSumTimestamp.cpp:193: DB::(anonymous namespace)::createAggregateFunctionDeltaSumTimestamp(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000002224ea3e 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839dd27 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 27. asan_thread_start(void*) @ 0x000000000aa45059 28. ? @ 0x00007f2f94fabac3 29. ? @ 0x00007f2f9503d850 2025.10.15 20:33:59.473450 [ 3019 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.524527 [ 3032 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.527913 [ 3032 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.558711 [ 3020 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:33:59.811017 [ 3035 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.026672 [ 3021 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.146017 [ 16872 ] {51c01a5d-6897-4a5a-8763-4192235aeea1} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50784) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:00.148172 [ 3016 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.159945 [ 16872 ] {51c01a5d-6897-4a5a-8763-4192235aeea1} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:00.195444 [ 3039 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.477505 [ 3052 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.528002 [ 3050 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.530871 [ 3030 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.562506 [ 3053 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:00.816518 [ 3055 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.029903 [ 3066 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.150892 [ 3073 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.198269 [ 3090 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.481358 [ 3091 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.531436 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.533795 [ 3103 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.565048 [ 3096 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:01.850740 [ 3110 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.033555 [ 3093 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.072487 [ 16958 ] {3438650c-4ffe-4694-94fc-29eb909e4297} executeQuery: Code: 57. DB::Exception: Table test.partitions already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50836) (comment: 00054_merge_tree_partitions.sql) (in query: CREATE TABLE test.partitions (EventDate Date, CounterID UInt32) ENGINE = MergeTree(EventDate, CounterID, 8192);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:02.083793 [ 16958 ] {3438650c-4ffe-4694-94fc-29eb909e4297} TCPHandler: Code: 57. DB::Exception: Table test.partitions already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:02.154258 [ 3115 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.201365 [ 3128 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.484044 [ 3134 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.536627 [ 3144 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.538518 [ 3131 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.557134 [ 12798 ] {864a865a-a984-4ce0-9ce1-80e1593f8b68} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50824) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:02.568003 [ 3138 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:02.569991 [ 12798 ] {864a865a-a984-4ce0-9ce1-80e1593f8b68} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:02.853403 [ 3160 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.036690 [ 3149 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.158636 [ 3162 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.204445 [ 3147 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.487617 [ 3225 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.541583 [ 3279 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.542503 [ 3280 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.572094 [ 3285 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:03.872829 [ 2850 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.039453 [ 2902 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.161805 [ 2939 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.207649 [ 2937 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.538254 [ 2984 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.544289 [ 2989 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.545013 [ 2979 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.574783 [ 2974 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:04.886323 [ 2990 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.056762 [ 2999 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.165204 [ 3009 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.211061 [ 3018 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.280460 [ 12798 ] {0aa56750-c850-471f-b2ce-31ec529a4063} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50864) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:05.300578 [ 12798 ] {0aa56750-c850-471f-b2ce-31ec529a4063} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:05.369093 [ 16872 ] {5f6608b3-a7b1-4a84-ba9f-5ee76cc1c701} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50876) (comment: 02922_deduplication_with_zero_copy.sh) (in query: insert into r2 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699edf3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699e8f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1d202 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026aee901 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::preFinalize() @ 0x0000000026aed91e 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8ed657 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000002cb25aa5 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 19. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a8b3 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:34:05.460688 [ 16872 ] {5f6608b3-a7b1-4a84-ba9f-5ee76cc1c701} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002699edf3 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x000000002699e8f4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026b1d202 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026aee901 10. ./contrib/llvm-project/libcxx/include/__split_buffer:88: DB::WriteBufferFromS3::preFinalize() @ 0x0000000026aed91e 11. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 12. ./build_docker/./src/IO/WriteBufferFromFileDecorator.cpp:69: DB::WriteBufferFromFileDecorator::preFinalize() @ 0x00000000280d5a1a 13. ./build_docker/./src/Storages/MergeTree/MergedBlockOutputStream.cpp:0: DB::MergedBlockOutputStream::finalizePartOnDisk(std::shared_ptr const&, DB::MergeTreeDataPartChecksums&) @ 0x000000002c8ed657 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::MergedBlockOutputStream::finalizePartAsync(std::shared_ptr const&, bool, DB::NamesAndTypesList const*, DB::MergeTreeDataPartChecksums*, std::vector>*) @ 0x000000002c8e95d4 15. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:683: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000002c968a72 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataWriter.cpp:444: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002c9631bf 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x000000002cb25aa5 18. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbf250e 19. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a8b3 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:34:05.541120 [ 3000 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.546503 [ 3032 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.547349 [ 3013 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.577320 [ 3026 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:05.819152 [ 16960 ] {f9e86224-df3a-437e-929c-52e89c6d439b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46290) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9b35 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:34:05.857512 [ 16960 ] {f9e86224-df3a-437e-929c-52e89c6d439b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b780b7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9b35 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 29. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 2025.10.15 20:34:05.890131 [ 3038 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.130339 [ 3016 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.171906 [ 3034 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.215641 [ 3062 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.544531 [ 3068 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.550385 [ 3064 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.551314 [ 3054 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.582998 [ 3085 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:06.893977 [ 3081 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.133851 [ 3090 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.175415 [ 3095 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.225402 [ 3058 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.556526 [ 3101 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.556981 [ 3070 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.586928 [ 3075 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.631781 [ 3107 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.896979 [ 3092 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:07.901052 [ 12798 ] {7d3bb589-6be7-44f5-8101-30cd86ad442c} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46308) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:07.931653 [ 12798 ] {7d3bb589-6be7-44f5-8101-30cd86ad442c} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:08.146441 [ 3108 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:08.178896 [ 3110 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:08.249244 [ 3079 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:08.559715 [ 3104 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:08.561294 [ 3115 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:08.636811 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:08.594188 [ 3111 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:08.899851 [ 3121 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.149807 [ 3133 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.182313 [ 3156 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.255735 [ 3125 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.564737 [ 3145 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.565509 [ 3147 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.640143 [ 3141 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.668618 [ 3161 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:09.766434 [ 16960 ] {8127926c-0f91-4faf-a248-005e295c8c2e} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46346) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:09.810068 [ 16960 ] {8127926c-0f91-4faf-a248-005e295c8c2e} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:09.936291 [ 3151 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.154971 [ 3164 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.193596 [ 3169 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.262149 [ 3171 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.587471 [ 3183 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.588328 [ 3184 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.643222 [ 3173 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.677494 [ 3194 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:10.951767 [ 3167 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.159897 [ 3206 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.197849 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.266295 [ 3207 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.396430 [ 16545 ] {85377ebf-a25a-4e50-bfcd-1c103e65f96d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46380) (comment: 00144_functions_of_aggregation_states.sql) (in query: SELECT EventDate, finalizeAggregation(state), runningAccumulate(state) FROM (SELECT EventDate, uniqState(UserID) AS state FROM test.hits 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:11.401186 [ 16545 ] {85377ebf-a25a-4e50-bfcd-1c103e65f96d} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:11.591594 [ 3215 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.592033 [ 3200 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.651204 [ 3220 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.680441 [ 3221 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:11.955547 [ 3231 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.120135 [ 16872 ] {f2a759fc-80bd-41e1-8036-7e73ce447f46} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46302) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 12068702;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:12.130331 [ 16872 ] {f2a759fc-80bd-41e1-8036-7e73ce447f46} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:12.163127 [ 3237 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.201851 [ 3235 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.270373 [ 3208 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.594942 [ 3241 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.595888 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.654931 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.684175 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:12.958947 [ 3245 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:13.166308 [ 3270 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:13.248318 [ 3256 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:13.281705 [ 3243 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:13.367276 [ 12798 ] {06205c41-46fc-4b46-aaf5-9899662d4f39} 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.10521.altinitytest (altinity build)) (from [::1]:46372) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 0, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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) @ 0x000000002ba1f4b4 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&) @ 0x000000002cbb5a1b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac3df 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:34:13.433761 [ 12798 ] {06205c41-46fc-4b46-aaf5-9899662d4f39} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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) @ 0x000000002ba1f4b4 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&) @ 0x000000002cbb5a1b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac3df 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:34:13.598334 [ 3276 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:13.601810 [ 3280 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:13.660262 [ 3248 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:13.687103 [ 3289 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.029273 [ 3271 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.175528 [ 3283 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.251291 [ 3291 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.285003 [ 3285 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.609038 [ 3297 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.609547 [ 3308 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.663641 [ 3282 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:14.690037 [ 3307 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.032387 [ 3191 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.103804 [ 16960 ] {f3d449a8-d464-4c01-b6f8-6b899547ff88} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46436) (comment: 01852_cast_operator_4.sql) (in query: EXPLAIN SYNTAX SELECT [3,4,5]::Array(Int64)[2]::Int8;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:15.107641 [ 16960 ] {f3d449a8-d464-4c01-b6f8-6b899547ff88} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=732). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:15.179537 [ 3304 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.253940 [ 3312 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.290734 [ 3313 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.293440 [ 3309 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.446300 [ 16958 ] {01ce03fd-013e-4163-91c1-ea39d456bf5f} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46420) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:15.452509 [ 16958 ] {01ce03fd-013e-4163-91c1-ea39d456bf5f} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:15.612505 [ 3328 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.614680 [ 3316 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.684287 [ 2832 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:15.693603 [ 3326 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.036002 [ 3266 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.182657 [ 2823 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.258030 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.293577 [ 2830 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.522303 [ 4168 ] {61b452c5-d44b-42ec-a786-d70b442c575f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46450) (comment: 00157_cache_dictionary.sql) (in query: DROP DICTIONARY IF EXISTS db_dict.cache_hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:34:16.529231 [ 4168 ] {61b452c5-d44b-42ec-a786-d70b442c575f} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:34:16.616999 [ 2825 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.618831 [ 2838 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.687194 [ 2853 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:16.697836 [ 2860 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.039095 [ 2843 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.185626 [ 2869 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.260515 [ 2859 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.297872 [ 2881 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.483590 [ 12800 ] {74473d14-0627-4244-a21f-bfb01b7c63b8} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 10.007015279 seconds, maximum: 10. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41992) (comment: 01249_flush_interactive.sh) (in query: SELECT DISTINCT number % 5 FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 8. ./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&)>) @ 0x0000000029b44a70 9. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:34:17.488765 [ 12800 ] {74473d14-0627-4244-a21f-bfb01b7c63b8} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 10.007015279 seconds, maximum: 10. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 7. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d35627e 8. ./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&)>) @ 0x0000000029b44a70 9. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.525574 [ 12800 ] {74473d14-0627-4244-a21f-bfb01b7c63b8} DynamicQueryHandler: Cannot send exception to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:41992). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 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&&) @ 0x000000001b0b9abf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bce02 4. ./src/Server/HTTP/HTTPServerResponse.h:165: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000002d1ebbca 5. ./src/Server/HTTP/HTTPServerResponse.h:0: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000002d1ea215 6. ./src/IO/WriteBuffer.h:66: DB::HTTPHandler::trySendExceptionToClient(String const&, int, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000002d07b14f 7. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:290: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0801e5 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.567788 [ 16960 ] {d85748a8-ff3f-4132-9248-78268af3aa0e} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35256) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:17.588744 [ 16960 ] {d85748a8-ff3f-4132-9248-78268af3aa0e} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:17.620274 [ 2885 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.623315 [ 2866 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.690304 [ 2889 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.703466 [ 2896 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:17.910557 [ 16871 ] {f8d53fb8-d6ca-4d7e-9cd8-d1e5678fe564} executeQuery: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_3', '.dict1'), 'second_column', toUInt64(11)). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46438) (comment: 01018_ddl_dictionaries_select.sql) (in query: SELECT dictGetUInt8(concat('test_3', '.dict1'), 'second_column', toUInt64(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000290f1d2f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000290f2b2a 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000b5dd9af 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b5d62d1 8. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5fc9a1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:34:17.914985 [ 16871 ] {f8d53fb8-d6ca-4d7e-9cd8-d1e5678fe564} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_3', '.dict1'), 'second_column', toUInt64(11)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000290f1d2f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000290f2b2a 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000b5dd9af 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b5d62d1 8. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5fc9a1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:34:18.042245 [ 2844 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.188601 [ 2897 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.263713 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.301832 [ 2911 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.623738 [ 2890 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.626783 [ 2923 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.693894 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.731612 [ 2918 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:18.932287 [ 16871 ] {a0004426-9d1d-46ea-940a-98ec1858ddfc} executeQuery: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_3', '.dict1'), 'second_column', toUInt64(11)). (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46438) (comment: 01018_ddl_dictionaries_select.sql) (in query: SELECT dictGetUInt8(concat('test_3', '.dict1'), 'second_column', toUInt64(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000290f1d2f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000290f2b2a 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000b5dd9af 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b5d62d1 8. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5fc9a1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:34:18.939480 [ 16871 ] {a0004426-9d1d-46ea-940a-98ec1858ddfc} TCPHandler: Code: 36. DB::Exception: Dictionary (`test_3.dict1`) not found: In scope SELECT dictGetUInt8(concat('test_3', '.dict1'), 'second_column', toUInt64(11)). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:164: DB::ExternalDictionariesLoader::resolveDictionaryName(String const&, String const&) const @ 0x00000000290f1d2f 5. ./build_docker/./src/Interpreters/ExternalDictionariesLoader.cpp:0: DB::ExternalDictionariesLoader::getDictionaryStructure(String const&, std::shared_ptr) const @ 0x00000000290f2b2a 6. DB::FunctionDictHelper::getDictionaryStructure(String const&) const @ 0x000000000b5dd9af 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000b5d62d1 8. DB::FunctionDictGetImpl, DB::NameDictGetUInt8, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5fc9a1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:34:19.045833 [ 2943 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.191875 [ 2916 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.266870 [ 2940 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.305294 [ 2945 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.627017 [ 2937 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.630169 [ 2948 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.697318 [ 2927 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.735060 [ 16960 ] {f9f8500b-26ba-42e1-96e0-af861fd21153} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35264) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:19.735310 [ 2956 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:19.745909 [ 16960 ] {f9f8500b-26ba-42e1-96e0-af861fd21153} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:19.771385 [ 16871 ] {520fd032-7005-4b69-ad90-43f1a8b4192d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=738). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46438) (comment: 01018_ddl_dictionaries_select.sql) (in query: SELECT dictGetUInt8(concat('test_3', '.dict1'), 'second_column', toUInt64(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:19.774571 [ 16871 ] {520fd032-7005-4b69-ad90-43f1a8b4192d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=738). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:20.049512 [ 2953 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:20.194774 [ 2950 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:20.272283 [ 2961 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:20.308758 [ 2917 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:20.630970 [ 2967 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:20.634078 [ 3112 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:20.700925 [ 2978 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:20.739020 [ 2977 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.052626 [ 2969 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.198110 [ 3003 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.283054 [ 3002 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.312276 [ 2996 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.634199 [ 3008 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.638339 [ 2975 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.704896 [ 3024 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:21.743509 [ 3010 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.055652 [ 3013 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.202566 [ 3001 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.287049 [ 3012 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.317008 [ 3025 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.637979 [ 3037 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.641764 [ 3027 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.711949 [ 3041 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.747483 [ 3016 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:22.997425 [ 4168 ] {53922d1a-7a74-48da-88ea-94d8ba511d1b} 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.10521.altinitytest (altinity build)) (from [::1]:35304) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:34:23.038480 [ 4168 ] {53922d1a-7a74-48da-88ea-94d8ba511d1b} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:34:23.059237 [ 3036 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:23.206800 [ 3044 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:23.291872 [ 3042 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:23.320038 [ 3054 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:23.645002 [ 3081 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:23.648258 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:23.715342 [ 3072 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:23.750709 [ 3076 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.062885 [ 3107 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.211258 [ 3086 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.307276 [ 3092 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.323508 [ 3116 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.647862 [ 3127 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.651037 [ 3104 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.718428 [ 3128 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:24.759282 [ 3111 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.068802 [ 3121 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.218154 [ 3144 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.310612 [ 3138 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.327784 [ 3137 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.650773 [ 3141 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.654245 [ 3161 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.722053 [ 3157 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:25.762349 [ 3142 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.071557 [ 3153 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.199659 [ 3171 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.221127 [ 3166 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.313741 [ 3179 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.331248 [ 3183 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.653617 [ 3180 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.657382 [ 3201 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.725337 [ 3131 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.762061 [ 4168 ] {3f37a69e-01ca-448a-b4f1-05ffecbc42bb} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41180) (comment: 00056_view.sql) (in query: DROP TABLE IF EXISTS test.view;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:34:26.765307 [ 3167 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:26.781716 [ 4168 ] {3f37a69e-01ca-448a-b4f1-05ffecbc42bb} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:34:27.073957 [ 3200 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:27.224086 [ 3177 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:27.347489 [ 3216 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:27.358134 [ 3233 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:27.661743 [ 3210 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:27.668905 [ 3208 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:27.723762 [ 16881 ] {d4b72ef7-03ea-46e5-9aa7-4d2fdd177935} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (3017fc27-0ee1-4d2c-bc96-0a82bcac7890). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:35288) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SELECT 'src_4', 4 FROM numbers(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:27.728577 [ 3240 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:27.740733 [ 16881 ] {d4b72ef7-03ea-46e5-9aa7-4d2fdd177935} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (3017fc27-0ee1-4d2c-bc96-0a82bcac7890). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:27.768393 [ 3230 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.076923 [ 3238 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.228183 [ 3225 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.350867 [ 3252 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.361034 [ 3270 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.665820 [ 3273 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.676625 [ 3274 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.732739 [ 3276 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:28.774925 [ 3280 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.081153 [ 3291 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.231813 [ 3300 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.354432 [ 3303 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.364309 [ 3294 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.669976 [ 3304 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.679726 [ 3321 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.787653 [ 3313 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:29.787795 [ 3293 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.086794 [ 3302 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.239687 [ 3316 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.359667 [ 3326 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.368340 [ 2832 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.673372 [ 3266 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.682784 [ 3322 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.791077 [ 2850 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:30.791642 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.088984 [ 2831 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.244749 [ 2838 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.363152 [ 2853 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.376291 [ 2837 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.443810 [ 16871 ] {11906b09-80f1-467e-84ac-480df128bac2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41228) (comment: 00175_counting_resources_in_subqueries.sql) (in query: SELECT count() FROM test.hits WHERE CounterID < (SELECT count() FROM test.hits WHERE NOT ignore(AdvEngineID));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:31.448198 [ 16871 ] {11906b09-80f1-467e-84ac-480df128bac2} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:31.678878 [ 2857 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.685795 [ 2862 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.794361 [ 2848 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.794995 [ 2865 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:31.786331 [ 12800 ] {1a19fa38-de4d-42f7-986a-719668432ba9} DynamicQueryHandler: Code: 271. DB::Exception: Cannot decompress Gorilla-encoded data. File has wrong header. (CANNOT_DECOMPRESS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Compression/CompressionCodecGorilla.cpp:0: DB::CompressionCodecGorilla::doDecompressData(char const*, unsigned int, char*, unsigned int) const @ 0x00000000277df7b4 5. ./build_docker/./src/Compression/ICompressionCodec.cpp:110: DB::ICompressionCodec::decompress(char const*, unsigned int, char*) const @ 0x00000000277fb969 6. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:27: non-virtual thunk to DB::CompressedReadBuffer::nextImpl() @ 0x0000000027761fc7 7. DB::ReadBuffer::next() @ 0x000000000b52aaeb 8. ./build_docker/./src/IO/ReadBuffer.cpp:0: DB::(anonymous namespace)::ReadBufferWrapper::nextImpl() @ 0x0000000026b4bdb5 9. DB::ReadBuffer::next() @ 0x000000000b52aaeb 10. ./src/IO/ReadBuffer.h:106: DB::ConcatReadBuffer::nextImpl() @ 0x00000000284b9499 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. ./src/IO/ReadBuffer.h:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b42e74 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.092406 [ 2858 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.248660 [ 2874 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.366368 [ 2885 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.379214 [ 2883 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.683025 [ 2884 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.689300 [ 2901 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.797342 [ 2891 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:32.798719 [ 2898 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.095902 [ 2893 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.251875 [ 2923 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.370759 [ 2908 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.382472 [ 2918 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.387952 [ 16871 ] {9dcf7d3d-187c-4bad-8320-76b1cd1e0d8f} executeQuery: Code: 46. DB::Exception: User-defined object '02101_test_function' doesn't exist: while removing user defined function `02101_test_function`. (UNKNOWN_FUNCTION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41258) (comment: 02101_sql_user_defined_functions_drop_if_exists.sql) (in query: DROP FUNCTION 02101_test_function;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLObjectsStorageBase.cpp:134: DB::UserDefinedSQLObjectsStorageBase::removeObject(std::shared_ptr const&, DB::UserDefinedSQLObjectType, String const&, bool) @ 0x000000002e017a07 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::unregisterFunction(std::shared_ptr const&, String const&, bool) @ 0x000000002dff50fd 6. ./build_docker/./src/Interpreters/InterpreterDropFunctionQuery.cpp:0: DB::InterpreterDropFunctionQuery::execute() @ 0x0000000029c3c399 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:33.395429 [ 16871 ] {9dcf7d3d-187c-4bad-8320-76b1cd1e0d8f} TCPHandler: Code: 46. DB::Exception: User-defined object '02101_test_function' doesn't exist: while removing user defined function `02101_test_function`. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Functions/UserDefined/UserDefinedSQLObjectsStorageBase.cpp:134: DB::UserDefinedSQLObjectsStorageBase::removeObject(std::shared_ptr const&, DB::UserDefinedSQLObjectType, String const&, bool) @ 0x000000002e017a07 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::UserDefinedSQLFunctionFactory::unregisterFunction(std::shared_ptr const&, String const&, bool) @ 0x000000002dff50fd 6. ./build_docker/./src/Interpreters/InterpreterDropFunctionQuery.cpp:0: DB::InterpreterDropFunctionQuery::execute() @ 0x0000000029c3c399 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:33.689065 [ 2946 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.691985 [ 2922 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.800082 [ 2945 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:33.802191 [ 2935 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.102866 [ 2948 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.254578 [ 2952 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.377578 [ 2944 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.385247 [ 2953 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.692206 [ 2959 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.695122 [ 2994 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.802882 [ 2979 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:34.805586 [ 2979 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.106347 [ 3002 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.257496 [ 2975 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.388280 [ 3009 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.417944 [ 2992 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.695517 [ 3013 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.698394 [ 3026 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.805942 [ 3033 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:35.831154 [ 3015 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.108856 [ 3039 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.260587 [ 3052 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.280637 [ 16871 ] {d0baa78f-ae4e-4fc9-920e-0ec94594bc0a} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(number, 1) FROM numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b83b 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:36.284299 [ 16871 ] {d0baa78f-ae4e-4fc9-920e-0ec94594bc0a} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual UInt64: In scope SELECT number.1 FROM numbers(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b83b 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:36.392325 [ 3030 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.424199 [ 3042 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.536509 [ 16871 ] {61b1752c-4d55-40f1-a635-67ff30bb124c} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000bb4c49a 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b92a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:36.546380 [ 16871 ] {61b1752c-4d55-40f1-a635-67ff30bb124c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t1) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000bb4c49a 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b92a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:36.699368 [ 3064 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.701483 [ 3056 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.809013 [ 3066 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.834766 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:36.996733 [ 16871 ] {86316997-0b7b-4773-aeb7-10ed33ee0abb} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 'b') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c5f3 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.001196 [ 16871 ] {86316997-0b7b-4773-aeb7-10ed33ee0abb} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'b': In scope SELECT tupleElement(t1, 'b') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c5f3 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.056358 [ 16960 ] {e6bda7dc-c59d-45ab-b8b0-b6ebf9f4edf1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45516) (comment: 02503_cache_on_write_with_small_segment_size.sh) (in query: select count() from ttt;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.079042 [ 16960 ] {e6bda7dc-c59d-45ab-b8b0-b6ebf9f4edf1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.111767 [ 3089 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:37.174912 [ 16871 ] {7c26111f-3aea-485f-a9b4-890662f0c6fe} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.179166 [ 16871 ] {7c26111f-3aea-485f-a9b4-890662f0c6fe} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t1.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.263517 [ 3074 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:37.294509 [ 16871 ] {4f35d111-0acf-4110-8885-e0aed67e6207} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.304102 [ 16871 ] {4f35d111-0acf-4110-8885-e0aed67e6207} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t1.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.395920 [ 3058 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:37.433779 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:37.586894 [ 16871 ] {81a954a5-dedd-4bce-9aa6-c898a9fdb4a0} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c4a2 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.593909 [ 16871 ] {81a954a5-dedd-4bce-9aa6-c898a9fdb4a0} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t1, materialize('a')) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c4a2 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:37.707953 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:37.709496 [ 3116 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:37.812671 [ 3108 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:37.838074 [ 3106 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.114928 [ 3111 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.245883 [ 16871 ] {7fc2a36d-7670-41a1-a42d-d7351cd3ec72} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000bb4c49a 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b92a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.252152 [ 16871 ] {7fc2a36d-7670-41a1-a42d-d7351cd3ec72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleElement doesn't match: passed 1, should be 2 or 3: In scope SELECT tupleElement(t2) FROM t_tuple_element. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000bb4c49a 4. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b92a 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.267055 [ 3132 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.340493 [ 16871 ] {013adf49-aff6-4045-b316-0056cccb3fd1} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 'a') FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c5f3 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.349106 [ 16871 ] {013adf49-aff6-4045-b316-0056cccb3fd1} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with name 'a': In scope SELECT tupleElement(t2, 'a') FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c5f3 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.403949 [ 3144 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.432273 [ 16871 ] {b497eaaa-f692-4d8d-af68-c186cb71e04e} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 0) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.437737 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.441598 [ 16871 ] {b497eaaa-f692-4d8d-af68-c186cb71e04e} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '0': In scope SELECT t2.0 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.534967 [ 16871 ] {af13d89c-2eb2-4fa6-a616-d90654b25743} executeQuery: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, 3) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.539582 [ 16871 ] {af13d89c-2eb2-4fa6-a616-d90654b25743} TCPHandler: Code: 10. DB::Exception: Tuple doesn't have element with index '3': In scope SELECT t2.3 FROM t_tuple_element. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000cbb20f4 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c545 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.594602 [ 16871 ] {48740d19-f236-45c9-8eea-44892b1d199e} executeQuery: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41286) (comment: 02116_tuple_element_analyzer.sql) (in query: SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c4a2 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.600762 [ 16871 ] {48740d19-f236-45c9-8eea-44892b1d199e} TCPHandler: Code: 43. DB::Exception: Second argument to tupleElement must be a constant UInt or String: In scope SELECT tupleElement(t2, materialize(1)) FROM t_tuple_element. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionTupleElement::getElementIndex(COW::immutable_ptr const&, DB::DataTypeTuple const&, unsigned long) const @ 0x000000001882c4a2 5. DB::(anonymous namespace)::FunctionTupleElement::getReturnTypeImpl(std::vector> const&) const @ 0x000000001882b60c 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.711903 [ 3136 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.713672 [ 3152 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.765110 [ 4168 ] {9b4ae442-1fe7-48fb-bf8b-25115a2c3cdb} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (fa916009-8740-44bc-b328-91c5dee5f70d). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41226) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SELECT 'src_' || toString(number), number FROM numbers(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.784251 [ 4168 ] {9b4ae442-1fe7-48fb-bf8b-25115a2c3cdb} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (fa916009-8740-44bc-b328-91c5dee5f70d). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 25. ./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*) @ 0x000000002d356ec7 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:34:38.816058 [ 3163 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:38.842298 [ 3151 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.118136 [ 3159 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.275260 [ 3185 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.414757 [ 3184 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.441271 [ 3172 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.715532 [ 3131 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.716638 [ 3167 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.830501 [ 3219 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:39.845715 [ 3176 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.121643 [ 3186 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.278197 [ 3221 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.418324 [ 3229 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.444473 [ 3216 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.718691 [ 3235 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.719727 [ 3237 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.834077 [ 3240 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:40.849966 [ 3242 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.124545 [ 3214 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.280813 [ 3236 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.421622 [ 3239 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.456727 [ 3270 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.722606 [ 3256 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.722904 [ 3262 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.837763 [ 3243 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:41.853264 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.128822 [ 3289 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.286374 [ 3277 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.424586 [ 3305 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.460117 [ 3300 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.460590 [ 16960 ] {31b5efd3-c4b9-4f16-8bed-fcef8c92f235} 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.10521.altinitytest (altinity build)) (from [::1]:45558) (comment: 01528_setting_aggregate_functions_null_for_empty.sql) (in query: SELECT sumOrNull(n) FROM defaults;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:42.477229 [ 16960 ] {31b5efd3-c4b9-4f16-8bed-fcef8c92f235} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:42.726122 [ 3297 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.726769 [ 3308 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.841196 [ 3299 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:42.855742 [ 3282 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.132778 [ 3312 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.142553 [ 16871 ] {f4a1be60-e737-4db1-b7aa-5a2357f913b2} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45572) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 0, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:43.152038 [ 16871 ] {f4a1be60-e737-4db1-b7aa-5a2357f913b2} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:43.291021 [ 3293 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.428030 [ 3323 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.452287 [ 12800 ] {3ddc65d4-b415-4a11-84ce-09c1fe3833be} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 46 ('numbers'): numbers. Expected one of: token, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42306) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 'find_me_[hidden]' FRRRROM numbers), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:34:43.460762 [ 12800 ] {3ddc65d4-b415-4a11-84ce-09c1fe3833be} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 46 ('numbers'): numbers. Expected one of: token, Comma, FROM, PREWHERE, WHERE, GROUP BY, WITH, HAVING, WINDOW, QUALIFY, ORDER BY, LIMIT, OFFSET, FETCH, SETTINGS, UNION, EXCEPT, INTERSECT, INTO OUTFILE, FORMAT, end of query. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.463264 [ 3319 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.730637 [ 3316 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.731582 [ 3310 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.843762 [ 2851 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:43.858236 [ 2839 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.137412 [ 3332 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.294440 [ 2850 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.431193 [ 2835 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.444667 [ 16871 ] {fa70c428-6808-4b92-a6d8-b2c2a54d3bb1} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45644) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x00000000283ca1d5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836db54 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ea12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:34:44.458443 [ 16871 ] {fa70c428-6808-4b92-a6d8-b2c2a54d3bb1} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x00000000283ca1d5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836db54 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ea12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 24. asan_thread_start(void*) @ 0x000000000aa45059 25. ? @ 0x00007f2f94fabac3 26. ? @ 0x00007f2f9503d850 2025.10.15 20:34:44.466858 [ 2845 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.733977 [ 2860 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.735382 [ 2867 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.847182 [ 2833 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.861607 [ 2864 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:44.871991 [ 12800 ] {e7595e26-c242-4fc0-b922-1b8b29b86e90} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42308) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 1 FROM system.numbers WHERE credit_card_number='find_me_[hidden]' 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x00000000283ca1d5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836db54 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ea12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 18. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 19. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:34:44.889095 [ 12800 ] {e7595e26-c242-4fc0-b922-1b8b29b86e90} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'credit_card_number' in scope SELECT 1 FROM system.numbers WHERE credit_card_number = 'find_me_[hidden]'. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x00000000283ca1d5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836db54 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835ea12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 11. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 14. ./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&) @ 0x000000002942671d 15. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 18. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 19. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 20. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.143298 [ 2865 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.297548 [ 2872 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.434677 [ 2855 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.471618 [ 2858 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.737392 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.826568 [ 2873 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.851011 [ 2885 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:45.865436 [ 2896 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.110610 [ 16871 ] {e81e2712-d144-4998-a0b1-14172ffa739b} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46656) (comment: 00956_sensitive_data_masking.sh) (in query: SELECT 'find_me_[hidden]', intDiv( 100, number - 10) FROM numbers(11) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000ffe7d89 5. void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012209319 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000125f7a8c 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000125e8d7a 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000125e5ee8 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000125dc63e 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125d92fa 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125d67e9 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 24. ./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*) @ 0x000000002d37c7d7 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 27. asan_thread_start(void*) @ 0x000000000aa45059 28. ? @ 0x00007f2f94fabac3 29. ? @ 0x00007f2f9503d850 2025.10.15 20:34:46.129534 [ 16871 ] {e81e2712-d144-4998-a0b1-14172ffa739b} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION intDiv(100_UInt8 :: 1, minus(__table1.number, 10_UInt8) :: 0) -> intDiv(100_UInt8, minus(__table1.number, 10_UInt8)) Int8 : 2'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. void DB::throwIfDivisionLeadsToFPE<_BitInt(8), long>(_BitInt(8), long) @ 0x000000000ffe7d89 5. void DB::impl_::BinaryOperation, _BitInt(8)>::process<(DB::impl_::OpCase)1>(char8_t const*, long const*, DB::impl_::BinaryOperation, _BitInt(8)>*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012209319 6. COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000125f7a8c 7. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>(auto const&) const::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000125e8d7a 8. bool DB::FunctionBinaryArithmetic::castType::castBothTypes::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x00000000125e5ee8 9. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x00000000125dc63e 10. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125d92fa 11. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000125d67e9 12. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb135 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 17. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 18. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 19. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 24. ./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*) @ 0x000000002d37c7d7 25. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 27. asan_thread_start(void*) @ 0x000000000aa45059 28. ? @ 0x00007f2f94fabac3 29. ? @ 0x00007f2f9503d850 2025.10.15 20:34:46.153628 [ 2887 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.300617 [ 2891 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.437869 [ 2897 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.474252 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.532099 [ 16960 ] {d18eae17-0994-4045-9748-c75681d40e06} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45628) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 0, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:46.552977 [ 16960 ] {d18eae17-0994-4045-9748-c75681d40e06} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:46.740853 [ 2893 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.829307 [ 2919 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.853921 [ 2890 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.868605 [ 2879 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:46.993235 [ 12800 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.156383 [ 2892 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.303054 [ 2913 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.440577 [ 2947 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.477285 [ 2938 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.743999 [ 2934 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.832342 [ 2914 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.857199 [ 2945 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:47.872113 [ 2935 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.159971 [ 2927 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.311311 [ 2936 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.445720 [ 2970 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.480038 [ 2944 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.751532 [ 2966 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.835063 [ 2976 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.861025 [ 2960 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:48.874677 [ 2963 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.162629 [ 2977 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.282445 [ 16871 ] {5c8abeb8-6ad7-4d3b-8061-f36feaf99cb1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46700) (comment: 00956_sensitive_data_masking.sh) (in query: select sleepEachRow(1) from numbers(10) where ignore('find_me_[hidden]')=0 and ignore('fwerkh_that_magic_string_make_me_unique') = 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000296004c4 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:34:49.304996 [ 16871 ] {5c8abeb8-6ad7-4d3b-8061-f36feaf99cb1} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/ProcessList.cpp:480: DB::QueryStatus::checkTimeLimit() @ 0x00000000296004c4 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:34:49.314412 [ 2982 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.449688 [ 2974 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.483139 [ 2987 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.627976 [ 4168 ] {77aff9af-7bf1-4119-baf2-2adbde9a6453} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46702) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:49.666353 [ 4168 ] {77aff9af-7bf1-4119-baf2-2adbde9a6453} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:34:49.754837 [ 2997 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.895306 [ 3003 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.895816 [ 2990 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:49.899765 [ 3003 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.165028 [ 3010 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.321048 [ 3032 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.452434 [ 3015 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.487531 [ 3012 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.758145 [ 3040 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.898435 [ 3034 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.899323 [ 3057 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:50.902428 [ 3057 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.171498 [ 3050 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.323611 [ 3085 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.455059 [ 3056 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.500866 [ 3069 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.768599 [ 3090 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.908282 [ 3061 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.908960 [ 3089 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:51.909375 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.174319 [ 3075 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.326728 [ 3086 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.458706 [ 3106 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.504322 [ 3103 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.772553 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.912992 [ 3120 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.913442 [ 3111 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:52.915059 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.177645 [ 3148 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.330383 [ 3143 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.461769 [ 3162 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.508296 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.776419 [ 3142 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.916909 [ 3170 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.917641 [ 3157 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:53.918730 [ 3164 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.181663 [ 3174 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.333896 [ 3183 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.464373 [ 3194 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.511781 [ 3180 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.779592 [ 3175 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.834478 [ 4168 ] {46ad004c-448e-4c4d-848a-fa9c0ca79534} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/06e/06e369af-68cd-4c9b-a022-a50e8e7996d6/202510_133_133_0/ in table system.query_log (06e369af-68cd-4c9b-a022-a50e8e7996d6) located on disk default of type local, from mark 0 with max_rows_to_read = 142): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46836) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: -- AsynchronousReaderIgnoredBytes = 0: no seek-avoiding happened -- CachedReadBufferReadFromSourceBytes = 0: sanity check to ensure we read only from cache SELECT ProfileEvents['AsynchronousReaderIgnoredBytes'], ProfileEvents['CachedReadBufferReadFromSourceBytes'] FROM system.query_log WHERE query_id = '02906_read_from_cache_12396' AND type = 'QueryFinish' AND event_date >= yesterday() AND current_database = currentDatabase() ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762a9b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000277676c1 14. DB::ReadBuffer::next() @ 0x000000000b52aaeb 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) @ 0x0000000027c14d10 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c12580 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 @ 0x0000000027aa3a5b 18. ./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>>>*) @ 0x000000002c7bc6ab 19. ./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>>&) @ 0x000000002c7f58fe 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de76ab4 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 31. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 2025.10.15 20:34:54.845155 [ 4168 ] {46ad004c-448e-4c4d-848a-fa9c0ca79534} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column query_id): (while reading from part /var/lib/clickhouse/store/06e/06e369af-68cd-4c9b-a022-a50e8e7996d6/202510_133_133_0/ in table system.query_log (06e369af-68cd-4c9b-a022-a50e8e7996d6) located on disk default of type local, from mark 0 with max_rows_to_read = 142): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762a9b 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000277676c1 14. DB::ReadBuffer::next() @ 0x000000000b52aaeb 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) @ 0x0000000027c14d10 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c12580 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 @ 0x0000000027aa3a5b 18. ./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>>>*) @ 0x000000002c7bc6ab 19. ./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>>&) @ 0x000000002c7f58fe 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 24. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 25. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 26. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e5e95 27. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 28. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de76ab4 29. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 30. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 31. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 2025.10.15 20:34:54.920001 [ 3205 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.920751 [ 3200 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:54.921974 [ 3215 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.185009 [ 3195 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.337440 [ 3209 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.466848 [ 3237 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.514837 [ 3210 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.782695 [ 3214 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.924043 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.924452 [ 3213 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:55.925870 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.188749 [ 3270 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.350108 [ 3256 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.469751 [ 3253 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.527087 [ 3255 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.715346 [ 4168 ] {20010d36-b55f-4eb8-937c-9480272bd423} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=10): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45934) (comment: 00956_sensitive_data_masking.sh) (in query: select * from system.query_log where current_database = currentDatabase() AND event_date >= yesterday() and query like '%TOPSECRET%';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:34:56.724416 [ 4168 ] {20010d36-b55f-4eb8-937c-9480272bd423} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=10): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ab9287 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:34:56.785555 [ 3217 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.927406 [ 3257 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.928256 [ 3246 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:56.930906 [ 3286 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.191323 [ 3296 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.353181 [ 3307 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.473358 [ 3313 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.523245 [ 4168 ] {be009583-a406-4427-94cf-a10e8ec40161} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45964) (in query: select count() from t_01889), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:57.529862 [ 3317 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.532277 [ 4168 ] {be009583-a406-4427-94cf-a10e8ec40161} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:34:57.788725 [ 3287 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.832229 [ 16871 ] {9fd34863-2d2e-4a49-9975-0c2dc4c9caa4} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (7af5f00e-eaf9-4302-bb2e-f14aae1f8ac3). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46852) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SETTINGS insert_deduplication_token='UDT' 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:34:57.865964 [ 16871 ] {9fd34863-2d2e-4a49-9975-0c2dc4c9caa4} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (7af5f00e-eaf9-4302-bb2e-f14aae1f8ac3). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:34:57.930335 [ 3310 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.931315 [ 3326 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:57.933578 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.194540 [ 3334 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.361505 [ 2830 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.476292 [ 2852 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.532651 [ 3318 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.791794 [ 2825 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.933670 [ 2853 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.934319 [ 2837 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:58.936471 [ 2853 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.198628 [ 2846 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.365238 [ 2871 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.495819 [ 3335 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.515163 [ 16551 ] {88064144-4e11-4a71-a11f-f67fed8c5aa6} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45994) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000294fb021 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000294fc5ed 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294fb721 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294fbd59 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b38604 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:34:59.539141 [ 2870 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.552633 [ 16551 ] {88064144-4e11-4a71-a11f-f67fed8c5aa6} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000294fb021 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000294fc5ed 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294fb721 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000294fbd59 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b38604 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:34:59.794016 [ 2873 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.936384 [ 2883 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.937096 [ 2866 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:34:59.938921 [ 2841 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.192158 [ 4168 ] {515061df-e3e3-46c7-81d3-975e1be9c744} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45980) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:00.201452 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.214336 [ 4168 ] {515061df-e3e3-46c7-81d3-975e1be9c744} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:00.369570 [ 2844 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.498909 [ 2903 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.542701 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.798535 [ 2920 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.942459 [ 2923 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.942899 [ 2829 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:00.943673 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.205268 [ 2910 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.372745 [ 2938 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.501335 [ 2922 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.545427 [ 2935 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.801682 [ 2948 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.945625 [ 2956 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.946064 [ 2936 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:01.946923 [ 2951 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.208286 [ 2971 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.378270 [ 2964 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.503858 [ 2982 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.549009 [ 2965 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.804709 [ 2979 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.948758 [ 3002 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.949326 [ 2997 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:02.949864 [ 2996 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.211240 [ 3006 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.381140 [ 3009 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.505742 [ 3019 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.552258 [ 3017 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.807770 [ 3026 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.959148 [ 3001 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.959747 [ 3012 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.960673 [ 3025 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:03.975236 [ 16551 ] {6fb8f3a0-ecca-4369-a94e-674970c19a3e} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46060) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 1000, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:03.990557 [ 16551 ] {6fb8f3a0-ecca-4369-a94e-674970c19a3e} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:04.214324 [ 3021 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:04.384007 [ 3039 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:04.593045 [ 3016 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:04.594049 [ 3052 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:04.811208 [ 3051 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:04.962264 [ 3066 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:04.963001 [ 3071 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:04.963139 [ 3081 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.220068 [ 3089 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.387817 [ 3065 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.596314 [ 3099 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.597071 [ 3101 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.813526 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.966254 [ 3106 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.967293 [ 3110 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:05.968260 [ 3109 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.251740 [ 3117 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.390946 [ 3127 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.599640 [ 3148 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.600414 [ 3118 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.816287 [ 3123 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.858612 [ 17626 ] {43338ef3-a4a9-439e-90a2-f1361464a449} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:46100) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 1000, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:06.875081 [ 17626 ] {43338ef3-a4a9-439e-90a2-f1361464a449} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:06.970038 [ 3156 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.970259 [ 3125 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:06.971908 [ 3138 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.260633 [ 3165 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.393795 [ 3142 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.602255 [ 3157 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.603054 [ 3164 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.819406 [ 3166 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.973119 [ 3146 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.974115 [ 3179 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:07.975734 [ 3183 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.227005 [ 16846 ] {4d274d50-4ce8-4bcc-830b-797a85b38ad3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43234) (comment: 00084_external_aggregation.sql) (in query: SELECT URL, uniq(SearchPhrase) AS u FROM test.hits GROUP BY URL ORDER BY u DESC, URL LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:35:08.231698 [ 16846 ] {4d274d50-4ce8-4bcc-830b-797a85b38ad3} TCPHandler: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:35:08.344710 [ 3131 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.396655 [ 3134 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.604972 [ 3178 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.605390 [ 3206 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.823396 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.976213 [ 3200 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.977074 [ 3215 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:08.978804 [ 3224 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.348166 [ 3229 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.399930 [ 3231 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.608414 [ 3199 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.608965 [ 3235 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.827101 [ 3242 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.869388 [ 16846 ] {40d54bc6-ddfe-48f2-8af1-e4e9a7863481} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43272) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: SELECT count() FROM test.hits WHERE positionCaseInsensitive(URL, 'metrika') != positionCaseInsensitive(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:35:09.879497 [ 16846 ] {40d54bc6-ddfe-48f2-8af1-e4e9a7863481} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:35:09.979277 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.979883 [ 3213 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:09.981213 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.350819 [ 3236 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.402854 [ 3254 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.611584 [ 3253 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.612725 [ 3281 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.921220 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.982726 [ 3272 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.983503 [ 3273 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:10.984235 [ 3274 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.353345 [ 3295 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.405794 [ 3278 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.613850 [ 3275 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.616126 [ 3275 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.924121 [ 3296 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.985573 [ 3288 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.986082 [ 3284 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:11.987600 [ 3268 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.363987 [ 3302 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.408864 [ 3287 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.616376 [ 3332 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.691400 [ 3439 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c6436924-6aa9-401d-be8b-6811ef6366a4::202510_1_160_32}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.700492 [ 2826 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.926961 [ 2845 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.988225 [ 2831 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.989055 [ 2838 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:12.990058 [ 2825 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.366929 [ 2864 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.411698 [ 2855 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.619761 [ 2861 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.704369 [ 2882 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.930538 [ 2889 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.991616 [ 2866 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.992786 [ 2841 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:13.993728 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.384465 [ 2844 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.414810 [ 2899 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.622505 [ 2893 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.707433 [ 2876 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.941743 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.995094 [ 2921 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.998839 [ 2892 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:14.999536 [ 2947 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:15.313076 [ 16551 ] {bf7e08c9-f4bc-4f54-95c4-4e63655870ef} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (fd3395a9-51c6-4524-8a2a-7465228d1343). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43248) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SETTINGS insert_deduplication_token='UDT' 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:35:15.356765 [ 16551 ] {bf7e08c9-f4bc-4f54-95c4-4e63655870ef} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (fd3395a9-51c6-4524-8a2a-7465228d1343). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:35:15.387047 [ 2958 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:15.418037 [ 2957 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:15.624940 [ 2971 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:15.710547 [ 2961 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:15.944946 [ 2967 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:15.998020 [ 2968 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.002306 [ 2986 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.002997 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.198644 [ 2960 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.389599 [ 2996 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.420956 [ 3004 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.628443 [ 2975 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.713084 [ 3006 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:16.948854 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.002074 [ 2991 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.006976 [ 3029 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.007550 [ 3017 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.392113 [ 3033 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.424416 [ 3001 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.631308 [ 3035 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.715779 [ 3021 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:17.951931 [ 3045 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.006854 [ 3879 ] {} test_1.table_a_b (9ff96115-6d97-4cdc-b13d-c734d4eba12d): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.15 20:35:18.007986 [ 3034 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.009725 [ 3016 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.017194 [ 3052 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.140612 [ 3879 ] {} DatabaseCatalog: Cannot drop table test_1.table_a_b (9ff96115-6d97-4cdc-b13d-c734d4eba12d). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c4864e5 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>*) @ 0x000000002c48482e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c490379 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1215: DB::StorageReplicatedMergeTree::drop() @ 0x000000002ba5fd6d 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286cb897 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286dd364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a6025 14. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.394838 [ 3048 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.427276 [ 3068 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.447441 [ 16736 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:519: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000286b6ec6 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x00000000285285a4 6. ./src/Common/SharedMutexHelper.h:91: DB::Context::setCurrentDatabase(String const&) @ 0x000000002854020a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000002d18b1aa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.535341 [ 16960 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database no_such_database_could_exist 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:519: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000286b6ec6 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x00000000285285a4 6. ./src/Common/SharedMutexHelper.h:91: DB::Context::setCurrentDatabase(String const&) @ 0x000000002854020a 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::TCPHandler::runImpl() @ 0x000000002d18b1aa 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.637552 [ 3063 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.718751 [ 3066 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:18.966975 [ 3067 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.011325 [ 3095 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.022085 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.061647 [ 3073 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.398322 [ 3101 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.430258 [ 3075 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.640456 [ 3116 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.721496 [ 3098 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:19.970640 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.025233 [ 3110 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.064852 [ 3109 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.096396 [ 3106 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.401431 [ 3148 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.433940 [ 3118 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.643983 [ 3140 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.724692 [ 3135 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:20.974430 [ 3100 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.028363 [ 3156 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.077627 [ 3133 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.099404 [ 3158 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.404529 [ 3161 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.437769 [ 3142 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.648155 [ 3168 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.727969 [ 3157 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:21.870024 [ 16958 ] {f4e79e46-d5e2-47f9-a1ba-10751fa5395e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36678) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:35:21.892283 [ 16958 ] {f4e79e46-d5e2-47f9-a1ba-10751fa5395e} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:35:21.977060 [ 3174 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.034010 [ 3185 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.080554 [ 3146 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.104699 [ 3188 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.409483 [ 3194 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.442489 [ 3175 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.658147 [ 3178 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.730894 [ 3186 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:22.980200 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.037953 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.083799 [ 3205 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.107530 [ 3200 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.413093 [ 3228 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.445545 [ 3199 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.660945 [ 3222 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.734326 [ 3223 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:23.984149 [ 3241 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.040988 [ 3214 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.087101 [ 3249 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.110528 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.175926 [ 17626 ] {4dc8661c-65f0-40c0-a673-631b40615745} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36690) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:24.207084 [ 17626 ] {4dc8661c-65f0-40c0-a673-631b40615745} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:24.416151 [ 3260 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.448420 [ 3247 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.716687 [ 3250 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.737744 [ 3281 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:24.883824 [ 17626 ] {328fb468-4364-4939-a6c5-4271ecca27d9} executeQuery: Code: 420. DB::Exception: Cannot UPDATE key column `d`. (CANNOT_UPDATE_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36826) (comment: 00652_mutations_alter_update.sh) (in query: ALTER TABLE alter_update UPDATE d = today() WHERE 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:474: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295ab0b0 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:35:24.891277 [ 17626 ] {328fb468-4364-4939-a6c5-4271ecca27d9} TCPHandler: Code: 420. DB::Exception: Cannot UPDATE key column `d`. (CANNOT_UPDATE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:474: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295ab0b0 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:35:24.987223 [ 3227 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.044072 [ 3232 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.094839 [ 3255 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.114561 [ 3272 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.419147 [ 3286 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.451284 [ 3246 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.719349 [ 3291 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.740891 [ 3269 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:25.953901 [ 16960 ] {ffdf8420-198e-4099-a98d-5cdaf85a35bb} executeQuery: Code: 420. DB::Exception: Cannot UPDATE key column `key`. (CANNOT_UPDATE_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43560) (comment: 00652_mutations_alter_update.sh) (in query: ALTER TABLE alter_update UPDATE key = 1 WHERE 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:474: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295ab0b0 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:35:25.972562 [ 16960 ] {ffdf8420-198e-4099-a98d-5cdaf85a35bb} TCPHandler: Code: 420. DB::Exception: Cannot UPDATE key column `key`. (CANNOT_UPDATE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:474: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295ab0b0 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:35:25.989931 [ 3300 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.047413 [ 3290 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.104613 [ 3294 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.117343 [ 3308 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.421868 [ 3282 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.454134 [ 3313 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.515474 [ 17626 ] {a5009c54-c337-4f26-86e2-fa337401fd2c} 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.10521.altinitytest (altinity build)) (from [::1]:43536) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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>) @ 0x000000002cbb7308 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>&&) @ 0x000000002cbb5eda 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac598 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:35:26.522832 [ 17626 ] {a5009c54-c337-4f26-86e2-fa337401fd2c} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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>) @ 0x000000002cbb7308 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>&&) @ 0x000000002cbb5eda 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac598 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:35:26.722112 [ 3314 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.744603 [ 3293 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:26.914049 [ 17626 ] {1fefdabb-1586-49ad-ab13-14def81730b8} executeQuery: Code: 420. DB::Exception: Cannot UPDATE materialized column `materialized_value`. (CANNOT_UPDATE_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43574) (comment: 00652_mutations_alter_update.sh) (in query: ALTER TABLE alter_update UPDATE materialized_value = 'aaa' WHERE 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:477: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295aaf90 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:35:26.922158 [ 17626 ] {1fefdabb-1586-49ad-ab13-14def81730b8} TCPHandler: Code: 420. DB::Exception: Cannot UPDATE materialized column `materialized_value`. (CANNOT_UPDATE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:477: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295aaf90 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:35:26.993010 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.049831 [ 3302 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.107288 [ 3316 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.120224 [ 3328 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.425677 [ 2840 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.457216 [ 3330 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.725217 [ 3324 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.748062 [ 3334 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:27.982548 [ 17626 ] {6f307540-9ad1-4c20-876c-e7540a99e2b3} executeQuery: Code: 43. DB::Exception: Illegal type String of first argument (condition) of function if. Must be UInt8.: While processing _CAST(if('string', _CAST('aaa', 'String'), value1), 'String'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43600) (comment: 00652_mutations_alter_update.sh) (in query: ALTER TABLE alter_update UPDATE value1 = 'aaa' WHERE 'string'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000011c3f3f8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8f2f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002824970d 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002878e5da 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000287a3e15 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000028792831 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1243: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000028793bd0 14. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002877a2ff 15. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000287302a1 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::appendExpression(DB::ExpressionActionsChain&, std::shared_ptr const&, bool) @ 0x000000002874d055 17. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1142: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b11fa 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295aa0a2 19. ./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) @ 0x000000002959e0a6 20. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000002959c795 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:35:28.000000 [ 17626 ] {6f307540-9ad1-4c20-876c-e7540a99e2b3} TCPHandler: Code: 43. DB::Exception: Illegal type String of first argument (condition) of function if. Must be UInt8.: While processing _CAST(if('string', _CAST('aaa', 'String'), value1), 'String'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000011c3f3f8 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa8f2f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 9. ./build_docker/./src/Interpreters/ActionsDAG.cpp:253: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x000000002824970d 10. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:0: DB::ScopeStack::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x000000002878e5da 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::Data::addFunction(std::shared_ptr const&, std::vector> const&, String) @ 0x00000000287a3e15 12. ./contrib/llvm-project/libcxx/include/string:1499: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000028792831 13. ./build_docker/./src/Interpreters/ActionsVisitor.cpp:1243: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000028793bd0 14. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000002877a2ff 15. ./src/Interpreters/InDepthNodeVisitor.h:0: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x00000000287302a1 16. ./build_docker/./src/Interpreters/ExpressionAnalyzer.cpp:0: DB::ExpressionAnalyzer::appendExpression(DB::ExpressionActionsChain&, std::shared_ptr const&, bool) @ 0x000000002874d055 17. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1142: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b11fa 18. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295aa0a2 19. ./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) @ 0x000000002959e0a6 20. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x000000002959c795 21. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 22. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 31. asan_thread_start(void*) @ 0x000000000aa45059 2025.10.15 20:35:28.000920 [ 2854 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:28.052547 [ 2849 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:28.109497 [ 2845 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:28.123189 [ 2824 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:28.428896 [ 2836 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:28.460062 [ 2857 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:28.728523 [ 2862 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:28.752486 [ 2853 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.004101 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.055413 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.112618 [ 2871 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.128596 [ 2834 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.431715 [ 2880 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.510388 [ 2885 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.731679 [ 2866 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:29.757063 [ 2841 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.007733 [ 2898 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.058167 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.115291 [ 2903 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.131680 [ 2906 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.434414 [ 2879 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.516392 [ 2904 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.734832 [ 2947 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:30.760055 [ 2926 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.011184 [ 2916 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.061219 [ 2940 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.118297 [ 2934 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.136846 [ 2942 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.436920 [ 2951 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.523387 [ 2936 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.738019 [ 2933 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:31.762932 [ 2944 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.016028 [ 2976 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.063769 [ 2917 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.124267 [ 2954 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.140019 [ 2963 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.439932 [ 2984 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.526261 [ 2978 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.793783 [ 3002 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:32.794247 [ 2996 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.019419 [ 3003 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.066815 [ 2975 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.127015 [ 2995 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.143099 [ 3006 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.443325 [ 3014 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.534312 [ 3028 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.796507 [ 3013 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:33.797627 [ 3020 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.022096 [ 3035 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.069625 [ 3038 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.133070 [ 3040 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.221906 [ 3052 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.446828 [ 3068 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.499369 [ 16960 ] {630ddfc3-001b-45ff-b54f-f8149bf6f266} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (4b377c6d-e5ec-4f0d-b76f-acf1e09d087d). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43584) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SETTINGS insert_deduplication_token='UDT' 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:35:34.538087 [ 3056 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.592670 [ 16960 ] {630ddfc3-001b-45ff-b54f-f8149bf6f266} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (4b377c6d-e5ec-4f0d-b76f-acf1e09d087d). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:35:34.799059 [ 3067 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:34.800959 [ 3089 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.025508 [ 3082 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.072553 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.135947 [ 3101 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.225284 [ 3070 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.453204 [ 3088 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.631285 [ 3106 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.844430 [ 3117 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:35.844602 [ 3111 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.028268 [ 3129 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.078387 [ 3079 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.138728 [ 3126 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.227809 [ 3148 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.377974 [ 17626 ] {99e5450b-64fa-4a39-b4a5-8e5babbecbee} executeQuery: Code: 57. DB::Exception: Table test_15.test_table already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43710) (comment: 01448_json_compact_strings_each_row.sql) (in query: CREATE TABLE test_table (`v1` String, `v2` UInt8, `v3` DEFAULT v2 * 16, `v4` UInt8 DEFAULT 8) ENGINE = MergeTree ORDER BY v2 SETTINGS index_granularity = 63395, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.29644185304641724, replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 35478645, compact_parts_max_bytes_to_buffer = 497648680, compact_parts_max_granules_to_buffer = 18, compact_parts_merge_max_bytes_to_prefetch_part = 26330361, merge_max_block_size = 15554, old_parts_lifetime = 270., 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 = 3590627315, index_granularity_bytes = 13288438, concurrent_part_removal_threshold = 83, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 78214, primary_key_compress_block_size = 50520), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:36.382257 [ 17626 ] {99e5450b-64fa-4a39-b4a5-8e5babbecbee} TCPHandler: Code: 57. DB::Exception: Table test_15.test_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:36.456585 [ 3114 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.641719 [ 3138 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.846985 [ 3162 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:36.847212 [ 3147 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.036762 [ 3161 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.082344 [ 3142 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.143650 [ 3163 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.230401 [ 3155 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.459881 [ 3164 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.644731 [ 3174 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.852492 [ 3183 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.852582 [ 3188 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:37.958393 [ 17626 ] {acc9e5b5-eb5e-4089-a011-9ee5172c3cbd} StorageBuffer (test_15.buffer_01817): Destination table test_15.data_01817 doesn't have column n. The default values are used. 2025.10.15 20:35:37.966719 [ 17626 ] {acc9e5b5-eb5e-4089-a011-9ee5172c3cbd} StorageBuffer (test_15.buffer_01817): Destination table test_15.data_01817 doesn't have column s. The default values are used. 2025.10.15 20:35:37.973137 [ 17626 ] {acc9e5b5-eb5e-4089-a011-9ee5172c3cbd} StorageBuffer (test_15.buffer_01817): Destination table test_15.data_01817 has no common columns with block in buffer. Block of data is skipped. 2025.10.15 20:35:38.039768 [ 3180 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:38.085102 [ 3167 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:38.146277 [ 3134 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:38.198589 [ 17626 ] {acc9e5b5-eb5e-4089-a011-9ee5172c3cbd} executeQuery: Code: 10. DB::Exception: Column `n` not found in table test_15.buffer_01817 (dd233ff5-803c-4862-82d3-6ee6303f64de). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57472) (comment: 01551_context_uaf.sql) (in query: select * from merge('', 'f');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:213: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x000000002bd61dbe 5. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::BufferSource::BufferSource(std::vector> const&, DB::StorageBuffer::Buffer&, std::shared_ptr const&) @ 0x000000002be694e6 6. ./build_docker/./src/Storages/StorageBuffer.cpp:420: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002be56c87 7. ./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 @ 0x000000002b98e16c 8. ./build_docker/./src/Storages/StorageMerge.cpp:646: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000002b98387f 9. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000002b97b089 10. ./build_docker/./src/Storages/StorageMerge.cpp:1582: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000002b99c346 11. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002dfa3a55 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002dfa368a 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df72d86 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de10e8a 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0f90b 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:35:38.202719 [ 17626 ] {acc9e5b5-eb5e-4089-a011-9ee5172c3cbd} TCPHandler: Code: 10. DB::Exception: Column `n` not found in table test_15.buffer_01817 (dd233ff5-803c-4862-82d3-6ee6303f64de). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:213: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x000000002bd61dbe 5. ./build_docker/./src/Storages/StorageBuffer.cpp:0: DB::BufferSource::BufferSource(std::vector> const&, DB::StorageBuffer::Buffer&, std::shared_ptr const&) @ 0x000000002be694e6 6. ./build_docker/./src/Storages/StorageBuffer.cpp:420: DB::StorageBuffer::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002be56c87 7. ./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 @ 0x000000002b98e16c 8. ./build_docker/./src/Storages/StorageMerge.cpp:646: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000002b98387f 9. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000002b97b089 10. ./build_docker/./src/Storages/StorageMerge.cpp:1582: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000002b99c346 11. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002dfa3a55 12. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002dfa368a 13. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df72d86 14. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de10e8a 15. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0f90b 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:35:38.233259 [ 3181 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:38.462900 [ 3212 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:38.647749 [ 3224 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:38.856059 [ 3196 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:38.856492 [ 3177 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.042612 [ 3216 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.088416 [ 3199 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.149793 [ 3237 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.235984 [ 3210 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.307350 [ 17626 ] {aaa09605-a223-4371-8a87-76776d18c609} 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.10521.altinitytest (altinity build)) (from [::1]:57506) (comment: 00652_mutations_alter_update.sh) (in query: ALTER TABLE alter_update DROP PARTITION 200001), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c4864e5 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>*) @ 0x000000002c48482e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2612: DB::MergeTreeData::clearOldPartsFromFilesystem(bool) @ 0x000000002c48449d 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:2076: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000002cbf61cc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5309: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002c4e460a 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291787d3 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:35:39.330377 [ 17626 ] {aaa09605-a223-4371-8a87-76776d18c609} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c4864e5 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>*) @ 0x000000002c48482e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:2612: DB::MergeTreeData::clearOldPartsFromFilesystem(bool) @ 0x000000002c48449d 10. ./build_docker/./src/Storages/StorageMergeTree.cpp:2076: DB::StorageMergeTree::dropPartition(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000002cbf61cc 11. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:5309: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000002c4e460a 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291787d3 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 22. asan_thread_start(void*) @ 0x000000000aa45059 23. ? @ 0x00007f2f94fabac3 24. ? @ 0x00007f2f9503d850 2025.10.15 20:35:39.466166 [ 3252 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.650792 [ 3236 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.880278 [ 16736 ] {1c8b26d3-03d2-4629-9114-b449d1fc267c} executeQuery: Code: 57. DB::Exception: Table test_1.table_when_b_even_and_joined already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57452) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_when_b_even_and_joined (`a_src` String, `a_join` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_when_b_even_and_joined', '1') ORDER BY (a_src, a_join, b) SETTINGS replicated_deduplication_window = 1000, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:39.898388 [ 16736 ] {1c8b26d3-03d2-4629-9114-b449d1fc267c} TCPHandler: Code: 57. DB::Exception: Table test_1.table_when_b_even_and_joined already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:39.918851 [ 3245 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:39.919132 [ 3258 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.074119 [ 3253 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.090890 [ 3232 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.139204 [ 16958 ] {d7320f21-2080-4b59-9bda-ef4406f39099} executeQuery: Code: 57. DB::Exception: Table test_15.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57514) (comment: 02495_analyzer_storage_join.sql) (in query: CREATE TABLE t1 (id2 UInt64, id1 Int64, val 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:40.155534 [ 16958 ] {d7320f21-2080-4b59-9bda-ef4406f39099} TCPHandler: Code: 57. DB::Exception: Table test_15.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:40.156933 [ 3255 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.244149 [ 3274 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.476343 [ 3286 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.653790 [ 3291 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.921311 [ 3305 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:40.921590 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.077022 [ 3297 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.093931 [ 3299 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.165102 [ 3268 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.247718 [ 3284 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.542084 [ 3314 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.656522 [ 3303 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.924359 [ 3323 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:41.925283 [ 3315 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.080125 [ 3287 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.096293 [ 3263 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.168140 [ 3316 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.250973 [ 3328 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.545315 [ 2823 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.659797 [ 2826 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.932231 [ 2822 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.932960 [ 2835 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:42.957929 [ 16958 ] {e9cbe75e-9a64-4910-a310-24d71e4abdcb} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57558) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:42.986665 [ 16958 ] {e9cbe75e-9a64-4910-a310-24d71e4abdcb} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:43.082993 [ 2831 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:43.159839 [ 2850 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:43.171150 [ 3325 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:43.253641 [ 2857 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:43.552277 [ 2848 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:43.662092 [ 2834 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:43.935241 [ 3335 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:43.935638 [ 2859 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.085410 [ 2882 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.173384 [ 2885 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.181320 [ 2873 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.281894 [ 2866 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.555710 [ 2902 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.664918 [ 2878 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.938609 [ 2912 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:44.941210 [ 2907 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.115403 [ 2928 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.176107 [ 2918 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.184187 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.285078 [ 2923 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.308802 [ 16871 ] {6b670355-811e-4db8-967f-72dc6aa16826} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:57620) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:45.320388 [ 16871 ] {6b670355-811e-4db8-967f-72dc6aa16826} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:45.568138 [ 2930 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.668337 [ 2946 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.944747 [ 2942 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:45.945885 [ 2955 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.117680 [ 2956 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.178542 [ 2951 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.186430 [ 2936 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.291557 [ 2933 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.571009 [ 2963 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.671327 [ 2962 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.947678 [ 2967 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:46.949093 [ 2986 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.121805 [ 2929 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.182540 [ 2969 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.188751 [ 2979 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.274576 [ 2987 ] {} test_1.table_when_b_even_and_joined (64b5cd39-f41c-4d8c-9d04-73d5b9af8b61): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/table_when_b_even_and_joined/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.300247 [ 2974 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.463983 [ 12800 ] {f22df68b-ef03-4506-8955-facb440f21ff} executeQuery: Code: 57. DB::Exception: Table test_5.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00163_column_oriented_formats.sh) (in query: /* ddl_entry=query-0000000011 */ CREATE TABLE test_5.`00163_column_oriented` UUID '8a1de924-0835-4e2a-a647-cccc6f06cb5f' (`ClientEventTime` DateTime('Asia/Dubai'), `MobilePhoneModel` String, `ClientIP6` FixedString(16)) ENGINE = File(ORC)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868a990 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686673 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027dae9a2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6348b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b185c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:35:47.505471 [ 12800 ] {f22df68b-ef03-4506-8955-facb440f21ff} executeQuery: Code: 57. DB::Exception: Table test_5.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:33954) (comment: 00163_column_oriented_formats.sh) (in query: CREATE TABLE 00163_column_oriented(ClientEventTime DateTime('Asia/Dubai'), MobilePhoneModel String, ClientIP6 FixedString(16)) ENGINE=File(ORC)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868a990 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686673 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027dae9a2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6348b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b185c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:35:47.522259 [ 12800 ] {f22df68b-ef03-4506-8955-facb440f21ff} TCPHandler: Code: 57. DB::Exception: Table test_5.`00163_column_oriented` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868a990 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x0000000028686673 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027dae9a2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6348b 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b185c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:35:47.574257 [ 2996 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.675427 [ 2990 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.950397 [ 3024 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:47.951985 [ 2992 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.125343 [ 3029 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.186139 [ 3033 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.191304 [ 3015 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.302812 [ 3021 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.494770 [ 12800 ] {850aa7ef-b121-4461-9cbb-b12d5c2cc9c3} executeQuery: Code: 641. DB::Exception: Cannot append data in format Arrow 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.10521.altinitytest (altinity build)) (from [::1]:33976) (comment: 00163_column_oriented_formats.sh) (in query: INSERT INTO 00163_column_oriented SELECT ClientEventTime, MobilePhoneModel, ClientIP6 FROM test.hits ORDER BY ClientEventTime, MobilePhoneModel, ClientIP6 LIMIT 100), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b7a7f6f 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&) @ 0x000000002db80832 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*) @ 0x000000002935705f 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&) @ 0x0000000029358e01 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002935c694 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029361e60 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:35:48.516298 [ 12800 ] {850aa7ef-b121-4461-9cbb-b12d5c2cc9c3} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Arrow 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000aafe574 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b7a7f6f 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&) @ 0x000000002db80832 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*) @ 0x000000002935705f 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&) @ 0x0000000029358e01 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002935c694 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029361e60 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:35:48.577505 [ 3031 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.679374 [ 3040 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.953068 [ 3016 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:48.955035 [ 3030 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.128595 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.194345 [ 3055 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.196103 [ 3063 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.305932 [ 3066 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.580320 [ 3090 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.694418 [ 3089 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.956397 [ 3099 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:49.958281 [ 3058 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.131466 [ 3116 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.206043 [ 3109 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.206478 [ 3106 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.308971 [ 3104 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.583091 [ 3120 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.697239 [ 3108 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.959527 [ 3139 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:50.960961 [ 3119 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.133857 [ 3158 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.208626 [ 3160 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.209510 [ 3152 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.311588 [ 3163 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.586144 [ 3153 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.706601 [ 3166 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.962486 [ 3173 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:51.964552 [ 3169 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.136685 [ 3184 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.212943 [ 3178 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.213475 [ 3193 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.314477 [ 3186 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.590495 [ 3196 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.709456 [ 3233 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.965538 [ 3231 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:52.967833 [ 3226 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.139045 [ 3239 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.215499 [ 3260 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.215903 [ 3270 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.317404 [ 3281 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.577153 [ 16871 ] {78a0fde5-7ea9-4ae5-8f07-c8235b9aac0f} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (b0c0acd1-5896-40ac-8c00-5779d8bab07a). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:33924) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SETTINGS insert_deduplication_token='UDT' 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:35:53.593856 [ 3295 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.712374 [ 3280 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.717514 [ 16871 ] {78a0fde5-7ea9-4ae5-8f07-c8235b9aac0f} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (b0c0acd1-5896-40ac-8c00-5779d8bab07a). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:35:53.968951 [ 3308 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:53.970717 [ 3297 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.145087 [ 3298 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.227693 [ 3261 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.227835 [ 3306 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.321235 [ 3312 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.596973 [ 3259 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.715686 [ 3319 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.972579 [ 2828 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:54.973941 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.148346 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.233342 [ 2822 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.234122 [ 2835 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.324941 [ 2831 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.602090 [ 2824 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.719162 [ 2853 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.974988 [ 2871 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:55.976198 [ 2834 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.151329 [ 2881 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.236980 [ 2861 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.240459 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.402513 [ 2873 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.604672 [ 2900 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.722291 [ 2902 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.722535 [ 16846 ] {81aae51e-bd5d-4f25-90fa-da4eba7ade2d} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:34108) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:56.739714 [ 16846 ] {81aae51e-bd5d-4f25-90fa-da4eba7ade2d} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:56.977445 [ 2886 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:56.978810 [ 2903 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.154031 [ 2912 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.240626 [ 2890 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.248197 [ 2879 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.404989 [ 2911 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.607366 [ 2921 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.724937 [ 2892 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.980184 [ 2940 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:57.982064 [ 2914 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.157091 [ 2955 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.248729 [ 2937 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.251187 [ 2952 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.412298 [ 2953 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.636604 [ 2917 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.728536 [ 2961 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.735974 [ 3435 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a58126e5-943b-4092-9d19-33afc9a0cd35::202510_1_144_44}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.983188 [ 2977 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:58.985734 [ 2929 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.159607 [ 2965 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.258290 [ 2978 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.259150 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.415047 [ 2959 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.638938 [ 2975 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.723037 [ 16871 ] {ef351e37-d1bb-4e91-86ee-bfbdf317f878} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38228) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:59.731813 [ 2999 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.746337 [ 16871 ] {ef351e37-d1bb-4e91-86ee-bfbdf317f878} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:35:59.985984 [ 3018 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:35:59.988164 [ 3014 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.161872 [ 3032 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.261588 [ 3009 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.262194 [ 3001 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.418590 [ 3037 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.648198 [ 3005 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.734614 [ 3047 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.988782 [ 3052 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:00.991184 [ 3022 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.032466 [ 4168 ] {c152dda1-cae4-4ad7-8da5-347df865aef0} executeQuery: Code: 420. DB::Exception: Updated column `value` affects MATERIALIZED column `key`, which is a key column. Cannot UPDATE it. (CANNOT_UPDATE_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38286) (comment: 00652_mutations_alter_update.sh) (in query: ALTER TABLE materialized_key UPDATE value = 1 WHERE 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:486: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295aa951 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:01.060430 [ 4168 ] {c152dda1-cae4-4ad7-8da5-347df865aef0} TCPHandler: Code: 420. DB::Exception: Updated column `value` affects MATERIALIZED column `key`, which is a key column. Cannot UPDATE it. (CANNOT_UPDATE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:486: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295aa951 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) @ 0x000000002959e0a6 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) @ 0x000000002959c795 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178528 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:01.164703 [ 3054 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.266524 [ 3063 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.266858 [ 3055 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.421569 [ 3062 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.650506 [ 3067 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.736912 [ 3059 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.991831 [ 3077 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:01.994062 [ 3099 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.167897 [ 3065 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.274539 [ 3091 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.277332 [ 3107 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.424847 [ 3102 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.653001 [ 3104 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.739504 [ 3111 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.993942 [ 3097 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:02.995945 [ 3128 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.171930 [ 3160 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.277242 [ 3145 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.280049 [ 3141 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.428563 [ 3151 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.667822 [ 3123 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.741824 [ 3170 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.996727 [ 3146 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:03.998965 [ 3179 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:04.175902 [ 3219 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:04.279813 [ 3186 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:04.282948 [ 3198 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:04.432146 [ 3205 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:04.670963 [ 3196 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:04.744501 [ 3229 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:04.999737 [ 3222 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:05.002311 [ 3208 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:05.246263 [ 3241 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:05.282047 [ 3238 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:05.285733 [ 3230 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:05.435819 [ 3189 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:05.673295 [ 3258 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:05.746843 [ 3232 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.012399 [ 3262 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.013296 [ 3277 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.250001 [ 3285 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.284871 [ 3308 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.287774 [ 3299 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.409238 [ 16871 ] {2aec37c9-5614-4eae-93dd-f07396251258} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (8d3fe504-bc65-4d3a-8f3c-811102d76dfa). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38272) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b SETTINGS insert_deduplication_token='UDT' 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:36:06.425888 [ 16871 ] {2aec37c9-5614-4eae-93dd-f07396251258} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (8d3fe504-bc65-4d3a-8f3c-811102d76dfa). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:36:06.442478 [ 3321 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.675557 [ 3326 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:06.749685 [ 3310 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.014643 [ 2828 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.015506 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.254473 [ 3318 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.287395 [ 3309 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.289871 [ 2838 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.445043 [ 3325 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.682237 [ 2857 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:07.752189 [ 2867 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.017191 [ 2871 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.017992 [ 2834 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.257073 [ 2861 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.292846 [ 2865 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.293065 [ 2836 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.448054 [ 2866 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.684980 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:08.755024 [ 2900 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.019898 [ 2886 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.021499 [ 2844 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.259440 [ 2905 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.295470 [ 2919 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.295971 [ 2928 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.320153 [ 16871 ] {bd6fb2b5-30b1-4814-98bb-161ed8673fd5} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48702) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:09.335985 [ 16871 ] {bd6fb2b5-30b1-4814-98bb-161ed8673fd5} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:09.450468 [ 2924 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.688016 [ 2908 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:09.757480 [ 2829 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.022848 [ 2876 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.024344 [ 2932 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.262111 [ 2922 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.298683 [ 2931 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.299096 [ 2941 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.460359 [ 2938 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.690716 [ 2944 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:10.759944 [ 2958 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.026492 [ 2971 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.027576 [ 2961 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.267948 [ 3112 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.301177 [ 2968 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.302533 [ 2977 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.463119 [ 2965 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.693393 [ 2982 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:11.790550 [ 2974 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.029132 [ 3002 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.030574 [ 2996 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.271603 [ 3007 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.303817 [ 2995 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.305130 [ 2999 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.424131 [ 5073 ] {} test_1.table_for_join_with (e33b8775-22f3-441e-8dba-a1e3b5d3ef3d): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.15 20:36:12.472764 [ 3010 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.672756 [ 5073 ] {} DatabaseCatalog: Cannot drop table test_1.table_for_join_with (e33b8775-22f3-441e-8dba-a1e3b5d3ef3d). 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c4864e5 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>*) @ 0x000000002c48482e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c490379 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286cb897 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286dd364 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a6025 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.696129 [ 2992 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:12.793583 [ 3028 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.032046 [ 3026 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.038205 [ 3013 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.274318 [ 3035 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.307607 [ 3043 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.308688 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.476346 [ 3047 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.699217 [ 3045 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:13.796288 [ 3022 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.047335 [ 3054 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.048415 [ 3085 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.277066 [ 3064 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.309786 [ 3063 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.311727 [ 3055 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.479827 [ 3066 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.553744 [ 3885 ] {} ExternalDictionaries: Could not update cache dictionary 'test_15.ssd_cache_dictionary (63f94957-52ad-4854-8ee2-cacc0ddb0695)', next update is scheduled at 2025-10-15 20:36:19: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): while reading column id at /var/lib/clickhouse/store/6d2/6d285fbe-1921-46b7-a258-83cd56608600/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000001b2081e5 13. DB::ReadBuffer::next() @ 0x000000000b52aaeb 14. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762a9b 15. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000277622f0 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b9b0b0 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 @ 0x0000000027aa3a5b 18. ./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>>>&) @ 0x000000002be0d347 19. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x000000002be0bab9 20. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 21. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 27. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000001bb2492b 28. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000001bb42eec 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000001bb49213 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.706244 [ 3089 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:14.733337 [ 16960 ] {e19eef6d-9efa-42e7-a5d6-34a3d3b873f6} executeQuery: Code: 510. DB::Exception: Update failed for dictionary 'test_15.ssd_cache_dictionary (63f94957-52ad-4854-8ee2-cacc0ddb0695)': Code: 510. DB::Exception: Update failed for dictionary test_15.ssd_cache_dictionary (63f94957-52ad-4854-8ee2-cacc0ddb0695) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): while reading column id at /var/lib/clickhouse/store/6d2/6d285fbe-1921-46b7-a258-83cd56608600/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000001b2081e5 13. DB::ReadBuffer::next() @ 0x000000000b52aaeb 14. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762a9b 15. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000277622f0 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b9b0b0 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 @ 0x0000000027aa3a5b 18. ./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>>>&) @ 0x000000002be0d347 19. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x000000002be0bab9 20. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 21. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 27. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000001bb2492b 28. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000001bb42eec 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000001bb49213 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff (version 24.8.14.10521.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10521.altinitytest (altinity build)): In scope SELECT dictGet('ssd_cache_dictionary', 'decimal_value', toUInt64(1)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48748) (comment: 01875_ssd_cache_dictionary_decimal256_type.sh) (in query: SELECT dictGet('ssd_cache_dictionary', 'decimal_value', toUInt64(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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000001bb48ef6 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb1cc14 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb1b8c3 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000b5d8ee9 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d35c3 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:36:14.739115 [ 16960 ] {e19eef6d-9efa-42e7-a5d6-34a3d3b873f6} TCPHandler: Code: 510. DB::Exception: Update failed for dictionary 'test_15.ssd_cache_dictionary (63f94957-52ad-4854-8ee2-cacc0ddb0695)': Code: 510. DB::Exception: Update failed for dictionary test_15.ssd_cache_dictionary (63f94957-52ad-4854-8ee2-cacc0ddb0695) : Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): while reading column id at /var/lib/clickhouse/store/6d2/6d285fbe-1921-46b7-a258-83cd56608600/: While executing Log. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. ./build_docker/./src/IO/LimitReadBuffer.cpp:36: DB::LimitReadBuffer::nextImpl() @ 0x000000001b2081e5 13. DB::ReadBuffer::next() @ 0x000000000b52aaeb 14. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762a9b 15. ./build_docker/./src/Compression/CompressedReadBuffer.cpp:43: DB::CompressedReadBuffer::readBig(char*, unsigned long) @ 0x00000000277622f0 16. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027b9b0b0 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 @ 0x0000000027aa3a5b 18. ./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>>>&) @ 0x000000002be0d347 19. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x000000002be0bab9 20. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 21. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 25. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d37f1d6 27. DB::CacheDictionary<(DB::DictionaryKeyType)0>::update(std::shared_ptr>) @ 0x000000001bb2492b 28. void std::__function::__policy_invoker>)>::__call_impl::CacheDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, std::shared_ptr, DB::CacheDictionaryUpdateQueueConfiguration, DB::CacheDictionaryConfiguration)::'lambda'(std::shared_ptr>), void (std::shared_ptr>)>>(std::__function::__policy_storage const*, std::shared_ptr>&&) @ 0x000000001bb42eec 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::updateThreadFunction() @ 0x000000001bb49213 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff (version 24.8.14.10521.altinitytest (altinity build)). (CACHE_DICTIONARY_UPDATE_FAIL) (version 24.8.14.10521.altinitytest (altinity build)): In scope SELECT dictGet('ssd_cache_dictionary', 'decimal_value', toUInt64(1)). (CACHE_DICTIONARY_UPDATE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44c97a 4. ./build_docker/./src/Dictionaries/CacheDictionaryUpdateQueue.cpp:117: DB::CacheDictionaryUpdateQueue<(DB::DictionaryKeyType)0>::waitForCurrentUpdateFinish(std::shared_ptr>&) const @ 0x000000001bb48ef6 5. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumns(std::vector> const&, std::vector, std::allocator>> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr, std::allocator::immutable_ptr>> const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb1cc14 6. DB::CacheDictionary<(DB::DictionaryKeyType)0>::getColumn(String const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::variant::immutable_ptr const>, std::reference_wrapper, 63ul, 64ul>>>) const @ 0x000000001bb1b8c3 7. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeDictionaryRequest(std::shared_ptr&, std::vector> const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, std::vector, std::allocator>> const&, std::shared_ptr const&, std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&) const @ 0x000000000b5d8ee9 8. DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b5d35c3 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccce1ab 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccec2a 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:36:14.799075 [ 3073 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.050663 [ 3077 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.051650 [ 3099 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.233989 [ 3065 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.280091 [ 3049 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.312819 [ 3061 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.322638 [ 3091 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.483659 [ 3116 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.711800 [ 3106 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:15.801744 [ 3104 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.056147 [ 3127 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.056696 [ 3129 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.282452 [ 3108 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.315903 [ 3128 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.325341 [ 3124 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.486438 [ 3118 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.715069 [ 3158 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:16.806000 [ 3160 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.059957 [ 3152 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.060883 [ 3147 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.129230 [ 4168 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.284851 [ 3151 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.318574 [ 3154 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.327954 [ 3157 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.489097 [ 3137 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.718340 [ 3153 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:17.809686 [ 3166 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.063328 [ 3183 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.063863 [ 3187 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.288961 [ 3180 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.321110 [ 3188 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.330688 [ 3167 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.491855 [ 3193 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.509302 [ 16960 ] {1e083a35-1bbc-40c8-b198-9d8828cf132b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=748): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60106) (comment: 03035_recursive_cte_postgres_1.sql) (in query: -- WITH RECURSIVE -- sum of 1..100 WITH RECURSIVE t AS ( SELECT 1 AS n UNION ALL SELECT n+1 FROM t WHERE n < 100 ) SELECT sum(n) FROM 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000002df15467 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x000000002df14ca8 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 10. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:36:18.533297 [ 16960 ] {1e083a35-1bbc-40c8-b198-9d8828cf132b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=748): While executing RecursiveCTESource. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:128: DB::RecursiveCTEChunkGenerator::generate() @ 0x000000002df15467 8. ./build_docker/./src/Processors/Sources/RecursiveCTESource.cpp:258: DB::RecursiveCTESource::generate() @ 0x000000002df14ca8 9. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 10. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:36:18.721182 [ 3197 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:18.815638 [ 3215 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.066416 [ 3216 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.076358 [ 3233 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.291578 [ 3237 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.323948 [ 3226 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.333352 [ 3214 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.494832 [ 3223 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.724135 [ 3270 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:19.869116 [ 3236 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.068814 [ 3281 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.079182 [ 3267 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.293786 [ 3274 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.326525 [ 3277 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.335705 [ 3248 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.498380 [ 3285 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.727372 [ 3307 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:20.880114 [ 3306 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.070867 [ 3314 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.081443 [ 3321 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.296281 [ 3316 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.340361 [ 3319 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.340834 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.500799 [ 3334 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.735839 [ 2822 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:21.765549 [ 16551 ] {0e93c2cb-ccd5-4815-89f2-5fa7e7de7f32} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (db3dd9a1-8ce0-417f-aae6-04a2570fa387). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:48726) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:36:21.839942 [ 16551 ] {0e93c2cb-ccd5-4815-89f2-5fa7e7de7f32} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (db3dd9a1-8ce0-417f-aae6-04a2570fa387). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:36:21.882712 [ 2833 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.072988 [ 2834 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.083827 [ 2855 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.180861 [ 2859 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.298657 [ 2873 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.342996 [ 2841 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.343740 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.504137 [ 2891 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.739101 [ 2898 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:22.885073 [ 2893 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.075929 [ 2928 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.088628 [ 2924 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.301560 [ 2829 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.345711 [ 2947 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.346764 [ 2892 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.506873 [ 2935 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.828309 [ 2934 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:23.887244 [ 2948 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.006195 [ 16871 ] {76f77a88-7b76-4d5e-9a6e-963d3ea70557} executeQuery: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60158) (comment: 01134_set_overflow_mode.sql) (in query: SELECT arrayJoin([5, 25]) IN (SELECT DISTINCT toUInt8(intDiv(number, 10)) FROM numbers(300));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b6e60 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b69f3 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000296763cc 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000029675478 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x0000000029674f5b 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:211: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x000000002d99f6b4 9. ./contrib/llvm-project/libcxx/include/vector:432: DB::IAccumulatingTransform::work() @ 0x000000002d32e8fb 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x000000002d998ffd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:36:24.008689 [ 16871 ] {76f77a88-7b76-4d5e-9a6e-963d3ea70557} TCPHandler: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b6e60 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b69f3 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000296763cc 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000029675478 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x0000000029674f5b 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:211: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x000000002d99f6b4 9. ./contrib/llvm-project/libcxx/include/vector:432: DB::IAccumulatingTransform::work() @ 0x000000002d32e8fb 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x000000002d998ffd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:36:24.078776 [ 2958 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.091399 [ 2917 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.304405 [ 3112 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.354465 [ 2929 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.354640 [ 2977 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.509573 [ 2987 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.831446 [ 2963 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.832576 [ 16871 ] {5c3eb2b2-5ae9-4732-a91b-fa3d1742c31e} executeQuery: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_LIMIT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60158) (comment: 01134_set_overflow_mode.sql) (in query: SELECT arrayJoin([5, 25]) IN (SELECT DISTINCT toUInt8(intDiv(number, 10)) FROM numbers(210));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b6e60 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b69f3 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000296763cc 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000029675478 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x0000000029674f5b 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:211: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x000000002d99f6b4 9. ./contrib/llvm-project/libcxx/include/vector:432: DB::IAccumulatingTransform::work() @ 0x000000002d32e8fb 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x000000002d998ffd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:36:24.834629 [ 16871 ] {5c3eb2b2-5ae9-4732-a91b-fa3d1742c31e} TCPHandler: Code: 191. DB::Exception: Limit for IN-set exceeded, max rows: 20.00, current rows: 21.00: While executing CreatingSetsTransform. (SET_SIZE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x00000000278b6e60 4. ./build_docker/./src/QueryPipeline/SizeLimits.cpp:24: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x00000000278b69f3 5. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, DB::SetKeyColumns&) @ 0x00000000296763cc 6. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromColumns(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&) @ 0x0000000029675478 7. ./build_docker/./src/Interpreters/Set.cpp:0: DB::Set::insertFromBlock(std::vector> const&) @ 0x0000000029674f5b 8. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:211: DB::CreatingSetsTransform::consume(DB::Chunk) @ 0x000000002d99f6b4 9. ./contrib/llvm-project/libcxx/include/vector:432: DB::IAccumulatingTransform::work() @ 0x000000002d32e8fb 10. ./build_docker/./src/Processors/Transforms/CreatingSetsTransform.cpp:102: DB::CreatingSetsTransform::work() @ 0x000000002d998ffd 11. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 12. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 13. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:36:24.890340 [ 3011 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:24.984335 [ 16871 ] {9061724c-30f6-4662-b593-bd41bc5c1c12} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60158) (comment: 01134_set_overflow_mode.sql) (in query: SELECT '---';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:24.987271 [ 16871 ] {9061724c-30f6-4662-b593-bd41bc5c1c12} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:25.086640 [ 3006 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:25.094406 [ 3010 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:25.310159 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:25.356896 [ 3014 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:25.357376 [ 3028 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:25.520252 [ 3013 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:25.744658 [ 16871 ] {1d6234a8-b5f1-4b72-bc24-cafe307aeca5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55490) (comment: 02375_analyzer_union.sql) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:25.765372 [ 16871 ] {1d6234a8-b5f1-4b72-bc24-cafe307aeca5} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:25.835056 [ 3005 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:25.893709 [ 3040 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.094522 [ 3039 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.097541 [ 3030 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.158502 [ 17626 ] {c2bf6859-59f0-4c83-9023-a9accae92031} executeQuery: Code: 57. DB::Exception: Table test_1.table_when_b_even_and_joined already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60150) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_when_b_even_and_joined (`a_src` String, `a_join` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_when_b_even_and_joined', '1') ORDER BY (a_src, a_join, b) SETTINGS replicated_deduplication_window = 1000, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:26.173479 [ 17626 ] {c2bf6859-59f0-4c83-9023-a9accae92031} TCPHandler: Code: 57. DB::Exception: Table test_1.table_when_b_even_and_joined already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:26.312679 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.359295 [ 3050 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.359980 [ 3036 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.522620 [ 3069 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.838694 [ 3073 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.896772 [ 3083 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:26.960081 [ 3443 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_295_300_1}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.096561 [ 3065 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.099660 [ 3074 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.315479 [ 3091 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.361885 [ 3075 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.436656 [ 3116 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.525058 [ 3110 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.841878 [ 3093 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:27.900856 [ 3111 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.099297 [ 3108 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.101857 [ 3097 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.320312 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.366925 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.394003 [ 16871 ] {cb3e8152-dbbc-4efd-bc90-a2e5fb80545f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Values. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55502) (comment: 02542_table_function_format.sql) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageProxy::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000265caea2 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:28.402015 [ 16871 ] {cb3e8152-dbbc-4efd-bc90-a2e5fb80545f} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Values. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageProxy::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000265caea2 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:28.439273 [ 3148 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.529108 [ 3133 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.844759 [ 3162 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:28.903512 [ 3136 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.101486 [ 3123 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.103908 [ 3168 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.324050 [ 3174 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.369776 [ 3146 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.442094 [ 3187 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.531924 [ 3188 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.768613 [ 17626 ] {7b6ecb31-ed15-4da7-a8a3-542e6d98e0f3} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55504) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:29.790309 [ 17626 ] {7b6ecb31-ed15-4da7-a8a3-542e6d98e0f3} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:29.847887 [ 3150 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:29.906321 [ 3206 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.106200 [ 3131 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.110761 [ 3176 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.331266 [ 3218 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.372170 [ 3195 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.444691 [ 3221 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.534711 [ 3222 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.576967 [ 4168 ] {55936b1e-7d18-4d06-bafe-0df439e376f5} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BADREQUEST'): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, ALTER query, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59930) (comment: 01071_http_header_exception_code.sh) (in query: BADREQUEST ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 2025.10.15 20:36:30.581239 [ 4168 ] {55936b1e-7d18-4d06-bafe-0df439e376f5} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 1 ('BADREQUEST'): BADREQUEST . Expected one of: Query, Query with output, EXPLAIN, EXPLAIN, SELECT query, possibly with UNION, list of union elements, SELECT query, subquery, possibly with UNION, SELECT subquery, SELECT query, WITH, FROM, SELECT, SHOW CREATE QUOTA query, SHOW CREATE, SHOW [FULL] [TEMPORARY] TABLES|DATABASES|CLUSTERS|CLUSTER|MERGES 'name' [[NOT] [I]LIKE 'str'] [LIMIT expr], SHOW, SHOW COLUMNS query, SHOW ENGINES query, SHOW ENGINES, SHOW FUNCTIONS query, SHOW FUNCTIONS, SHOW INDEXES query, SHOW SETTING query, SHOW SETTING, EXISTS or SHOW CREATE query, EXISTS, DESCRIBE FILESYSTEM CACHE query, DESCRIBE, DESC, DESCRIBE query, SHOW PROCESSLIST query, SHOW PROCESSLIST, CREATE TABLE or ATTACH TABLE query, CREATE, ATTACH, REPLACE, CREATE DATABASE query, CREATE VIEW query, CREATE DICTIONARY, CREATE LIVE VIEW query, CREATE WINDOW VIEW query, ALTER query, ALTER TABLE, ALTER TEMPORARY TABLE, ALTER DATABASE, RENAME query, RENAME DATABASE, RENAME TABLE, EXCHANGE TABLES, RENAME DICTIONARY, EXCHANGE DICTIONARIES, RENAME, DROP query, DROP, DETACH, TRUNCATE, UNDROP query, UNDROP, ALTER query, CHECK ALL TABLES, CHECK TABLE, KILL QUERY query, KILL, OPTIMIZE query, OPTIMIZE TABLE, WATCH query, WATCH, SHOW ACCESS query, SHOW ACCESS, ShowAccessEntitiesQuery, SHOW GRANTS query, SHOW GRANTS, SHOW PRIVILEGES query, SHOW PRIVILEGES, BACKUP or RESTORE query, BACKUP, RESTORE, INSERT query, INSERT INTO, USE query, USE, SET ROLE or SET DEFAULT ROLE query, SET ROLE DEFAULT, SET ROLE, SET DEFAULT ROLE, SET query, SET, SYSTEM query, SYSTEM, CREATE USER or ALTER USER query, ALTER USER, CREATE USER, CREATE ROLE or ALTER ROLE query, ALTER ROLE, CREATE ROLE, CREATE QUOTA or ALTER QUOTA query, ALTER QUOTA, CREATE QUOTA, CREATE ROW POLICY or ALTER ROW POLICY query, ALTER POLICY, ALTER ROW POLICY, CREATE POLICY, CREATE ROW POLICY, CREATE SETTINGS PROFILE or ALTER SETTINGS PROFILE query, ALTER SETTINGS PROFILE, ALTER PROFILE, CREATE SETTINGS PROFILE, CREATE PROFILE, CREATE FUNCTION query, DROP FUNCTION query, CREATE NAMED COLLECTION, DROP NAMED COLLECTION query, Alter NAMED COLLECTION query, ALTER, CREATE INDEX query, DROP INDEX query, DROP access entity query, MOVE access entity query, MOVE, GRANT or REVOKE query, REVOKE, GRANT, EXTERNAL DDL query, EXTERNAL DDL FROM, TCL query, BEGIN TRANSACTION, START TRANSACTION, COMMIT, ROLLBACK, SET TRANSACTION SNAPSHOT, Delete query, DELETE. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000aaf0710 3. ./build_docker/./src/Parsers/parseQuery.cpp:407: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8135 4. ./build_docker/./src/Parsers/parseQuery.cpp:420: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x000000002e9f8245 5. ./build_docker/./src/Interpreters/executeQuery.cpp:784: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b37aea 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4369f 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.784605 [ 16871 ] {952b65b8-2eb5-43ab-afac-51ec17c7e871} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55526) (comment: 03210_convert_outer_join_to_inner_join_any_join.sql) (in query: -- Expected 3 rows, got only 1. Removing 'ANY' and adding 'FINAL' fixes -- the issue (but it is not always possible). Moving filter by 'country' to -- an outer query doesn't help. Query without filter by 'country' works -- as expected (returns 3 rows). SELECT * FROM user_transactions ANY LEFT JOIN user_country USING (user_id) WHERE user_id = 1 AND country = 'US' ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:36:30.797470 [ 16871 ] {952b65b8-2eb5-43ab-afac-51ec17c7e871} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:36:30.850475 [ 3265 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:30.909047 [ 3210 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.108613 [ 3249 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.113192 [ 3202 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.333781 [ 3247 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.374605 [ 3254 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.447288 [ 3258 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.536861 [ 3253 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.853451 [ 3279 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:31.911928 [ 3264 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.111519 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.115841 [ 3301 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.336704 [ 3269 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.377590 [ 3300 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.450619 [ 3299 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.539262 [ 3298 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.856140 [ 3320 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.915738 [ 2840 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:32.936757 [ 16871 ] {b67c70b3-25c0-4d75-b217-eb298948be47} executeQuery: Code: 57. DB::Exception: Table test_3.dict already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55550) (comment: 01036_no_superfluous_dict_reload_on_create_database.sql) (in query: CREATE DICTIONARY dict (`key` UInt64 DEFAULT 0, `val` UInt64 DEFAULT 10) PRIMARY KEY key SOURCE(CLICKHOUSE(HOST 'localhost' PORT tcpPort() USER 'default' TABLE 'dict_data' PASSWORD '[HIDDEN]' DB currentDatabase())) LIFETIME(MIN 0 MAX 0) LAYOUT(FLAT())), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:32.958493 [ 16871 ] {b67c70b3-25c0-4d75-b217-eb298948be47} TCPHandler: Code: 57. DB::Exception: Table test_3.dict already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:33.114508 [ 3310 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:33.119229 [ 3310 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:33.339845 [ 2847 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:33.380567 [ 3191 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:33.453961 [ 2849 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:33.543000 [ 3312 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:33.859211 [ 2833 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:33.919133 [ 2867 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.118921 [ 2827 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.129246 [ 2881 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.214059 [ 17626 ] {418454b3-4d82-4420-9796-661233e26495} executeQuery: Code: 57. DB::Exception: Table test_1.mv_b_even already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55530) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE MATERIALIZED VIEW mv_b_even TO table_when_b_even_and_joined AS SELECT a_src, a_join, table_for_join_with.b as b FROM table_a_b FULL OUTER JOIN table_for_join_with ON table_a_b.b = table_for_join_with.b AND table_a_b.b % 2 = 0 ORDER BY a_src, a_join, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:34.228444 [ 17626 ] {418454b3-4d82-4420-9796-661233e26495} TCPHandler: Code: 57. DB::Exception: Table test_1.mv_b_even already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:34.342745 [ 2882 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.383961 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.456683 [ 2873 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.546116 [ 2836 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.862255 [ 2891 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:34.922005 [ 2878 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.121587 [ 2885 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.132051 [ 2893 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.346241 [ 2919 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.386998 [ 2928 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.459640 [ 2905 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.548749 [ 2923 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.865157 [ 2911 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.884963 [ 17626 ] {5d910473-3833-4138-ab3f-02ed0ce4ef70} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55578) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:35.910444 [ 17626 ] {5d910473-3833-4138-ab3f-02ed0ce4ef70} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:35.924630 [ 2914 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:35.967285 [ 16871 ] {1693efae-580c-496e-b8f4-08fa668f952f} executeQuery: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55568) (comment: 02864_statistics_bugs.sql) (in query: SELECT count(*) FROM bug_67742 WHERE a < '10.5';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e361a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaceaf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133f8110 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133c61d1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 13. ./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) @ 0x000000002825cda8 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002825a797 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000002d9da601 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000002ddc16a1 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000293c7007 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943fbd5 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029432ec9 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:36:35.970083 [ 16871 ] {1693efae-580c-496e-b8f4-08fa668f952f} TCPHandler: Code: 53. DB::Exception: Cannot convert string '10.5' to type Int32. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000e9e361a 4. ./build_docker/./src/Interpreters/convertFieldToType.cpp:559: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaceaf 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aa6aa1 6. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133f8110 7. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133c61d1 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 13. ./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) @ 0x000000002825cda8 14. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x000000002825a797 15. ./build_docker/./src/Processors/Transforms/FilterTransform.cpp:0: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x000000002d9da601 16. ./build_docker/./src/Processors/QueryPlan/FilterStep.cpp:0: DB::FilterStep::FilterStep(DB::DataStream const&, DB::ActionsDAG, String, bool) @ 0x000000002ddc16a1 17. ./contrib/llvm-project/libcxx/include/string:1499: std::__unique_if::__unique_single std::make_unique[abi:v15007](DB::DataStream const&, DB::ActionsDAG&&, String&, bool&) @ 0x00000000293c7007 18. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addFilterStep(DB::QueryPlan&, DB::FilterAnalysisResult&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000002943fbd5 19. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029432ec9 20. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 21. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:36:36.124085 [ 2941 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:36.134761 [ 2952 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:36.349187 [ 2951 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:36.389756 [ 2945 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:36.462374 [ 2917 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:36.560050 [ 2973 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:36.867942 [ 2986 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:36.927179 [ 2968 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.133076 [ 2969 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.137333 [ 2979 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.255504 [ 16871 ] {172907bb-91c3-4d92-8023-34f53f232a34} executeQuery: Code: 57. DB::Exception: Table test_3.bug_67742 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:55568) (comment: 02864_statistics_bugs.sql) (in query: CREATE TABLE bug_67742 (`a` Int16 STATISTICS(tdigest)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 54069, min_bytes_for_wide_part = 855762851, ratio_of_defaults_for_sparse_serialization = 0.3275693655014038, replace_long_file_name_to_hash = true, max_file_name_length = 115, min_bytes_for_full_part_storage = 241100418, compact_parts_max_bytes_to_buffer = 42570848, compact_parts_max_granules_to_buffer = 238, compact_parts_merge_max_bytes_to_prefetch_part = 2164305, merge_max_block_size = 5454, old_parts_lifetime = 110., 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 = 5758598771, index_granularity_bytes = 3539349, concurrent_part_removal_threshold = 80, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 75734, primary_key_compress_block_size = 11457), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:37.258897 [ 16871 ] {172907bb-91c3-4d92-8023-34f53f232a34} TCPHandler: Code: 57. DB::Exception: Table test_3.bug_67742 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:37.351888 [ 2959 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.394141 [ 2996 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.465047 [ 2949 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.563455 [ 2984 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.870599 [ 3029 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:37.929812 [ 3017 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.135643 [ 3025 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.143300 [ 3035 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.354343 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.398170 [ 3038 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.558191 [ 3027 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.566039 [ 3032 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.669569 [ 17626 ] {34d30b50-f6a7-4b55-ba58-c9945ab64229} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58990) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:38.673087 [ 17626 ] {34d30b50-f6a7-4b55-ba58-c9945ab64229} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:38.873042 [ 3048 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:38.950728 [ 3085 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.138168 [ 3063 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.145845 [ 3055 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.356763 [ 3067 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.401021 [ 3066 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.560915 [ 3083 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.609335 [ 3101 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.877736 [ 3061 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:39.956414 [ 3075 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.140922 [ 3098 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.148949 [ 3116 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.365042 [ 3111 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.403817 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.563462 [ 3144 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.611939 [ 3118 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.880966 [ 3119 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:40.959020 [ 3148 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.147486 [ 3129 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.151422 [ 3133 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.367693 [ 3138 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.417045 [ 3136 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.566778 [ 3161 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.614900 [ 3151 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.643564 [ 16871 ] {8b4bf4be-ab8b-452e-9f53-b00965a641f0} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:59004) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:41.670862 [ 16871 ] {8b4bf4be-ab8b-452e-9f53-b00965a641f0} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:41.883886 [ 3143 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:41.963866 [ 3153 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.149703 [ 3159 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.153900 [ 3171 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.370309 [ 3219 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.424302 [ 3201 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.569955 [ 3181 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.618148 [ 3134 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.886261 [ 3176 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:42.966706 [ 3198 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.152211 [ 3193 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.156482 [ 3224 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.237834 [ 17626 ] {9b6f8d15-7713-4e1e-afba-236e88c0051c} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:59042) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:43.248796 [ 17626 ] {9b6f8d15-7713-4e1e-afba-236e88c0051c} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:43.372636 [ 3209 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.427541 [ 3228 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.573061 [ 3235 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.621188 [ 3199 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.888520 [ 3229 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:43.969055 [ 3226 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.154630 [ 3210 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.159736 [ 3238 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.375202 [ 3220 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.432086 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.575383 [ 3256 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.623615 [ 3281 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.891048 [ 3262 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:44.971989 [ 3277 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.160804 [ 3276 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.165266 [ 3291 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.377755 [ 3285 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.435743 [ 3301 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.577430 [ 3275 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.625690 [ 3294 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.893211 [ 3261 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:45.974775 [ 3313 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.163324 [ 3293 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.167620 [ 3320 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.379866 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.438491 [ 2832 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.579618 [ 2854 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.637512 [ 3191 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.898152 [ 3312 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:46.977823 [ 3309 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.165463 [ 2846 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.170137 [ 3332 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.382889 [ 2862 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.440774 [ 2827 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.584162 [ 2859 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.641413 [ 2853 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.901378 [ 2884 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:47.980635 [ 2891 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.167823 [ 2912 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.172301 [ 2907 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.385589 [ 2890 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.444001 [ 2919 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.596602 [ 2905 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.644697 [ 2923 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.904346 [ 2930 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:48.983155 [ 2935 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.170389 [ 2934 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.174657 [ 2938 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.388029 [ 2966 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.416240 [ 16871 ] {4146840c-ade4-48bc-8518-e8538265ffc2} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (b2d4385e-8fe4-4d2a-a629-f059b93587d0). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:59058) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:36:49.441122 [ 16871 ] {4146840c-ade4-48bc-8518-e8538265ffc2} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (b2d4385e-8fe4-4d2a-a629-f059b93587d0). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:36:49.446909 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.600268 [ 2988 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.647575 [ 2965 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.907147 [ 2987 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:49.985787 [ 2978 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.172753 [ 2949 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.176982 [ 3003 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.391141 [ 2995 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.451992 [ 3024 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.603979 [ 3028 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.719563 [ 3017 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.909602 [ 2991 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:50.988383 [ 3038 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.150458 [ 17626 ] {a335261f-a786-4e5f-9656-2cb70853cc66} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Values. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44626) (comment: 01914_index_bgranvea.sql) (in query: DROP TABLE IF 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageProxy::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000265caea2 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:51.159227 [ 17626 ] {a335261f-a786-4e5f-9656-2cb70853cc66} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Values. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageProxy::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000265caea2 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:36:51.175771 [ 3027 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.179561 [ 3037 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.393488 [ 3047 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.454830 [ 3045 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.607187 [ 3030 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.722560 [ 3051 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.779104 [ 5064 ] {} test_1.table_a_b (aa6cf48a-7c5d-40de-a9fa-65400ce84231): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.15 20:36:51.780718 [ 5064 ] {} DatabaseCatalog: Cannot drop table test_1.table_a_b (aa6cf48a-7c5d-40de-a9fa-65400ce84231). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c4864e5 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>*) @ 0x000000002c48482e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c490379 10. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:1215: DB::StorageReplicatedMergeTree::drop() @ 0x000000002ba5fd6d 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286cb897 12. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286dd364 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a6025 14. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba546c 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 16. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 17. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 19. asan_thread_start(void*) @ 0x000000000aa45059 20. ? @ 0x00007f2f94fabac3 21. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.912456 [ 3012 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:51.991259 [ 3016 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.178544 [ 3053 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.181929 [ 3068 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.423426 [ 3073 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.445170 [ 3433 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {24310d89-f4f4-4694-b8de-dac7140488d3::202510_1_172_112}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.458311 [ 3101 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.610362 [ 3092 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.725095 [ 3116 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.915120 [ 3088 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:52.993761 [ 3087 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.180728 [ 3139 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.183942 [ 3140 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.426920 [ 3152 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.463727 [ 3138 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.547275 [ 17626 ] {750b3498-55d4-4463-8042-df7fb1a235d4} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_3.table_for_rename1 (912885f3-1467-44f0-ab87-266de90c34d6) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44628) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&&, String&&, String&) @ 0x0000000027b8a175 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000002d98b05c 5. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 12. ./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*) @ 0x000000002d356ec7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:53.552161 [ 17626 ] {750b3498-55d4-4463-8042-df7fb1a235d4} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_3.table_for_rename1 (912885f3-1467-44f0-ab87-266de90c34d6) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&&, String&&, String&) @ 0x0000000027b8a175 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000002d98b05c 5. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 12. ./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*) @ 0x000000002d356ec7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:53.617451 [ 3142 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.728308 [ 3157 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.917869 [ 3153 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:53.996029 [ 3159 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.183413 [ 3149 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.186533 [ 3172 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.430833 [ 3176 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.465727 [ 3192 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.620852 [ 3215 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.731181 [ 3130 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.920697 [ 3216 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:54.999181 [ 3199 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:55.186032 [ 3210 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:55.188932 [ 3238 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:55.433799 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:55.467968 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:55.623539 [ 3281 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:55.734137 [ 3255 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:55.922953 [ 3277 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.006575 [ 3291 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.188453 [ 3271 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.191247 [ 3217 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.436178 [ 3301 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.470607 [ 3257 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.630678 [ 3275 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.736930 [ 3288 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:56.935216 [ 3304 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.009633 [ 3321 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.070902 [ 16871 ] {dfb0d952-c2be-42e7-896d-14d0281f0521} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44604) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:57.088467 [ 16871 ] {dfb0d952-c2be-42e7-896d-14d0281f0521} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:57.190800 [ 3303 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.193330 [ 3302 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.395088 [ 17626 ] {b30afbe7-d9cb-441f-bdaf-1729a374beed} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_3.table_for_rename1 (912885f3-1467-44f0-ab87-266de90c34d6) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44628) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(10, 10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&&, String&&, String&) @ 0x0000000027b8a175 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000002d98b05c 5. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 12. ./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*) @ 0x000000002d356ec7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:57.402691 [ 17626 ] {b30afbe7-d9cb-441f-bdaf-1729a374beed} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_3.table_for_rename1 (912885f3-1467-44f0-ab87-266de90c34d6) is violated at row 1. Expression: (toInt64(value5) < toInt64(value3)). Column values: value5 = '11', value3 = '10'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&&, String&&, String&) @ 0x0000000027b8a175 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000002d98b05c 5. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 12. ./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*) @ 0x000000002d356ec7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:36:57.438365 [ 3292 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.473858 [ 3322 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.633312 [ 2823 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.785574 [ 3266 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:57.938330 [ 3331 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.012435 [ 2849 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.192852 [ 3318 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.195461 [ 2856 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.441032 [ 2872 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.560768 [ 2842 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.636150 [ 2834 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.788295 [ 2864 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:58.940999 [ 2841 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.015404 [ 2886 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.194832 [ 2919 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.203981 [ 2928 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.446232 [ 2943 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.563463 [ 2947 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.639744 [ 2930 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.790893 [ 2937 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:36:59.943121 [ 2953 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.017803 [ 2917 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.197662 [ 2972 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.206102 [ 2986 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.449243 [ 2979 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.565950 [ 2959 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.642877 [ 2993 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.793072 [ 2963 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:00.945422 [ 3013 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.020383 [ 3009 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.212167 [ 3027 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.212449 [ 3037 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.455703 [ 3022 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.569788 [ 3039 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.645445 [ 3044 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.800026 [ 3071 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:01.947906 [ 3067 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.023064 [ 3076 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.215382 [ 3049 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.215604 [ 3092 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.404304 [ 16871 ] {0d26723c-2f61-4f53-88c5-eb89fbf24ee8} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (9531f03c-3407-4ef1-9f84-4a0262ec9dea). (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60138) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: -- first insert INSERT INTO table_a_b 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:37:02.458424 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.469278 [ 16871 ] {0d26723c-2f61-4f53-88c5-eb89fbf24ee8} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column a_join to destination column a_join: while executing 'FUNCTION _CAST(a_join :: 1, String :: 4) -> _CAST(a_join, String) String : 3': while pushing to view test_1.mv_b_even (9531f03c-3407-4ef1-9f84-4a0262ec9dea). (CANNOT_INSERT_NULL_IN_ORDINARY_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl const&, std::shared_ptr const&, bool) const::'lambda0'(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) @ 0x000000000b300f26 5. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf4e8b 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccee5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd07e4 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000286ffedd 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9d368e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49c3df 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d334339 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 16. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 17. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db89bbb 18. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d2a7e 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1745 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 24. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:105: DB::PushingPipelineExecutor::push(DB::Chunk) @ 0x000000002d3864f8 25. ./build_docker/./src/Processors/Executors/PushingPipelineExecutor.cpp:0: DB::PushingPipelineExecutor::push(DB::Block) @ 0x000000002d38686e 26. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processInsertQuery() @ 0x000000002d19a684 27. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186ed8 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 2025.10.15 20:37:02.572962 [ 3097 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.647833 [ 3108 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.802845 [ 3140 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:02.950410 [ 3133 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.025312 [ 3129 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.217799 [ 3136 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.218257 [ 3141 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.460871 [ 3170 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.576856 [ 3169 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.654982 [ 3188 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.686643 [ 17626 ] {7a8d038b-646e-473c-8d13-d651e4e238af} executeQuery: Code: 469. DB::Exception: Constraint `cs_value1` for table test_3.table_for_rename1 (912885f3-1467-44f0-ab87-266de90c34d6) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44628) (comment: 01277_alter_rename_column_constraint_zookeeper_long.sql) (in query: INSERT INTO table_for_rename1 SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number), toString(number + 2) from numbers(20, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&&, String&&, String&) @ 0x0000000027b8a175 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000002d98b05c 5. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 12. ./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*) @ 0x000000002d356ec7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:03.690417 [ 17626 ] {7a8d038b-646e-473c-8d13-d651e4e238af} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value1` for table test_3.table_for_rename1 (912885f3-1467-44f0-ab87-266de90c34d6) is violated at row 1. Expression: (toInt64(value1) < toInt64(value2)). Column values: value1 = '20', value2 = '20'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&, unsigned long&&, String&&, String&) @ 0x0000000027b8a175 4. ./build_docker/./src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x000000002d98b05c 5. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9d271a 6. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9d2231 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9d1386 8. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 9. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 12. ./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*) @ 0x000000002d356ec7 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:03.805659 [ 3180 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:03.953143 [ 3149 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.028748 [ 3181 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.220593 [ 3201 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.221713 [ 3190 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.463384 [ 3204 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.579378 [ 3193 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.658015 [ 3224 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.808045 [ 3130 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.873125 [ 16881 ] {5eae22e3-606a-45ad-b771-dbf0ef060e99} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60180) (comment: 01825_type_json_1.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:37:04.882683 [ 16881 ] {5eae22e3-606a-45ad-b771-dbf0ef060e99} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2a6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8434e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f836a3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002853f14d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x00000000294fa95b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:37:04.929073 [ 12800 ] {e2bb7218-5143-4ca6-8fb4-19c6a2418f7c} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60170) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:04.960903 [ 3209 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:04.967977 [ 12800 ] {e2bb7218-5143-4ca6-8fb4-19c6a2418f7c} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:05.032128 [ 3222 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:05.223589 [ 3240 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:05.224302 [ 3242 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:05.465634 [ 3210 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:05.581741 [ 3244 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:05.660711 [ 3251 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:05.810956 [ 3214 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:05.964600 [ 3260 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.035755 [ 3247 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.226877 [ 3256 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.227459 [ 3254 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.468559 [ 3270 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.584197 [ 3232 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.663572 [ 3245 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.813617 [ 3286 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:06.968098 [ 3276 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.044008 [ 3217 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.230289 [ 3269 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.252633 [ 3300 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.418367 [ 16881 ] {fb8a3f4b-c037-400e-9ebc-45faa39f8c69} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54350) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 0, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:07.428629 [ 16881 ] {fb8a3f4b-c037-400e-9ebc-45faa39f8c69} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:07.471554 [ 3307 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.501686 [ 16958 ] {fa97b470-c075-47cd-84b0-7f5748cdee6f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:60154) (comment: 02944_dynamically_change_filesystem_cache_size.sh) (in query: SELECT count() FROM system.filesystem_cache WHERE state = 'DOWNLOADED'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:37:07.510435 [ 16958 ] {fa97b470-c075-47cd-84b0-7f5748cdee6f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:37:07.586570 [ 3321 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.665920 [ 3320 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.816896 [ 3302 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:07.970987 [ 3298 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.046733 [ 3323 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.249256 [ 2823 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.255535 [ 2828 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.474571 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.588830 [ 2856 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.669085 [ 2833 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.823242 [ 3332 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:08.973898 [ 2837 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.049344 [ 2877 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.252058 [ 2871 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.257862 [ 2859 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.477828 [ 2896 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.591946 [ 2836 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.677072 [ 2873 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.766079 [ 16551 ] {825f1e28-9f5b-4f19-accb-946a81b31f92} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54382) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 0, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:09.771096 [ 16551 ] {825f1e28-9f5b-4f19-accb-946a81b31f92} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:09.826535 [ 2894 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:09.977024 [ 2893 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.051939 [ 2878 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.254785 [ 2919 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.260798 [ 2928 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.481562 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.590945 [ 12800 ] {6945b936-0030-4ac2-bc6a-46ad4aa55620} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54356) (comment: 02769_parallel_replicas_unavailable_shards.sql) (in query: SELECT ProfileEvents['ParallelReplicasUnavailableCount'] FROM system.query_log WHERE yesterday() <= event_date AND query_id in (select query_id from system.query_log where log_comment = '02769_7b513191-5082-4073-8568-53b86a49da79' and current_database = currentDatabase()) and type = 'QueryFinish' and query_id == initial_query_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:37:10.595778 [ 2910 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.601404 [ 12800 ] {6945b936-0030-4ac2-bc6a-46ad4aa55620} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 25. asan_thread_start(void*) @ 0x000000000aa45059 26. ? @ 0x00007f2f94fabac3 27. ? @ 0x00007f2f9503d850 2025.10.15 20:37:10.681874 [ 2943 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.829760 [ 2915 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:10.980067 [ 2942 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.054482 [ 2931 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.265799 [ 2941 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.266252 [ 2934 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.484096 [ 2945 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.656866 [ 2967 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.685616 [ 2957 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.845596 [ 2981 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:11.982743 [ 2965 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.034747 [ 16551 ] {42f4c89a-b7af-40a1-9dc3-2f3cba0fed99} executeQuery: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54386) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_a_b (`a_src` String, `b` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_a_b', '1') ORDER BY (a_src, b) SETTINGS replicated_deduplication_window = 0, index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:12.041223 [ 16551 ] {42f4c89a-b7af-40a1-9dc3-2f3cba0fed99} TCPHandler: Code: 57. DB::Exception: Table test_1.table_a_b already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:12.057312 [ 2962 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.268184 [ 2987 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.268975 [ 3002 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.486449 [ 2984 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.659004 [ 3010 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.687812 [ 3008 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.851460 [ 3018 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.982400 [ 12800 ] {2eb93c64-a184-4b05-96c3-f8ef17a8b2d7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54398) (comment: 02155_read_in_order_max_rows_to_read.sql) (in query: SELECT a FROM t_max_rows_to_read WHERE a = 10 OR a = 20 SETTINGS max_rows_to_read = 12;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:12.984759 [ 3013 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:12.985565 [ 12800 ] {2eb93c64-a184-4b05-96c3-f8ef17a8b2d7} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:13.064161 [ 3019 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:13.270087 [ 3043 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:13.270977 [ 3023 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:13.488961 [ 3021 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:13.661593 [ 2991 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:13.690311 [ 3032 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:13.854377 [ 3047 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:13.991653 [ 3060 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.066566 [ 3030 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.272112 [ 3036 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.273220 [ 3016 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.350758 [ 16551 ] {e4cda1c5-319a-4260-90db-5efa6b1dd539} executeQuery: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:54414) (comment: 03008_deduplication_mv_generates_several_blocks_replicated.sh) (in query: CREATE TABLE table_for_join_with (`a_join` String, `b` UInt64) ENGINE = MergeTree ORDER BY (a_join, b) SETTINGS index_granularity = 30140, min_bytes_for_wide_part = 419765649, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 345252459, compact_parts_max_bytes_to_buffer = 167078139, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 20460805, merge_max_block_size = 16628, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 6819767097, index_granularity_bytes = 1631594, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 78021, primary_key_compress_block_size = 90133), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:14.376816 [ 16551 ] {e4cda1c5-319a-4260-90db-5efa6b1dd539} TCPHandler: Code: 57. DB::Exception: Table test_1.table_for_join_with already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:14.491567 [ 3064 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.664355 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.692852 [ 3068 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.857203 [ 3089 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:14.994464 [ 3082 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.072496 [ 3065 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.275179 [ 3072 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.275945 [ 3107 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.496388 [ 3098 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.668361 [ 3116 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.696592 [ 3094 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.863026 [ 3106 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:15.997305 [ 3079 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:16.080722 [ 3088 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:16.278002 [ 3139 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:16.278665 [ 3118 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:16.507427 [ 3129 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:16.672160 [ 3114 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:16.700143 [ 3121 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:16.868329 [ 3122 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.000799 [ 3151 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.087256 [ 3165 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.280374 [ 3174 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.281000 [ 3161 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.516526 [ 3169 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.675237 [ 3180 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.702889 [ 3146 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:17.871445 [ 3150 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.004072 [ 3175 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.090069 [ 3194 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.282833 [ 3176 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.283449 [ 3204 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.527439 [ 3205 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.681663 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.705029 [ 3130 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:18.874561 [ 3221 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.009526 [ 3235 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.093028 [ 3240 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.285969 [ 3226 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.287127 [ 3231 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.531109 [ 3244 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.688518 [ 3251 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.708082 [ 3189 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:19.876953 [ 3214 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.012796 [ 3230 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.095873 [ 3260 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.289141 [ 3247 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.290245 [ 3236 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.534190 [ 3250 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.692174 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.712464 [ 3252 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:20.880249 [ 3227 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.015410 [ 3270 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.104881 [ 3245 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.291901 [ 3274 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.294436 [ 3248 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.537194 [ 3291 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.696668 [ 3305 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.716264 [ 3280 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:21.883191 [ 3269 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.018488 [ 3307 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.107560 [ 3284 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.295873 [ 3311 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.297451 [ 3296 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.556198 [ 3317 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.700484 [ 3316 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.718657 [ 2840 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:22.886355 [ 3330 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.021985 [ 2839 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.110577 [ 2847 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.302962 [ 3287 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.303508 [ 2845 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.559743 [ 2854 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.703565 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.725419 [ 3328 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:23.889191 [ 2837 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.024789 [ 2827 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.118974 [ 2842 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.306055 [ 2871 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.310836 [ 2859 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.562783 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.706286 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.728592 [ 2888 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:24.898184 [ 2902 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.027951 [ 2894 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.121479 [ 2895 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.309140 [ 2887 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.313713 [ 2885 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.566563 [ 2879 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.709815 [ 2890 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.735848 [ 2928 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:25.900777 [ 2909 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.030881 [ 2897 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.124720 [ 2913 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.312483 [ 2923 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.319382 [ 2910 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.569770 [ 2943 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.721739 [ 2906 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.746200 [ 2947 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:26.904189 [ 2926 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.044188 [ 2915 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.127295 [ 2914 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.327112 [ 2939 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.328238 [ 2931 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.572676 [ 2937 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.724458 [ 2948 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.749228 [ 2951 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:27.907734 [ 2945 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.046584 [ 2933 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.130355 [ 2967 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.330899 [ 2925 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.331480 [ 2954 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.575126 [ 2964 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.727795 [ 2993 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.751903 [ 2960 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:28.910272 [ 2987 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.049437 [ 3011 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.133496 [ 2976 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.333340 [ 3028 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.334283 [ 2992 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.577783 [ 3007 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.745520 [ 2975 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.754598 [ 3019 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:29.912543 [ 3025 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.051800 [ 2999 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.135872 [ 3021 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.336324 [ 3040 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.338126 [ 3034 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.580396 [ 3039 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.747796 [ 3051 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.756907 [ 3042 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:30.914950 [ 3048 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.059709 [ 3020 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.138277 [ 3036 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.339042 [ 3064 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.340540 [ 3062 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.564349 [ 5085 ] {} ExternalDictionariesLoader: Could not update external dictionary '87a03aa5-cf3a-464d-b766-8e0e9aaa39cf', leaving the previous version, next update is scheduled at 2025-10-15 20:37:37: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): (while reading column third_column): (while reading from part /var/lib/clickhouse/store/dda/dda7b3ca-e4e8-46e0-a4cd-49e5b1d5aa02/all_1_1_0/ in table test_3.table_for_dict (dda7b3ca-e4e8-46e0-a4cd-49e5b1d5aa02) located on disk default of type local, from mark 0 with max_rows_to_read = 100): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266033a2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026602db4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x00000000266002e7 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265e9dbd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ea9b3 11. DB::ReadBuffer::next() @ 0x000000000b52aaeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b583216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027762d10 14. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x00000000277676c1 15. DB::ReadBuffer::next() @ 0x000000000b52aaeb 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c14d10 17. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c12580 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 @ 0x0000000027aa3a5b 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>>>*) @ 0x000000002c7bc6ab 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>>&) @ 0x000000002c7f58fe 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7d3eea 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7ea5d3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7e6023 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c83747b 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002deb5454 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e719 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.583061 [ 3076 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.759636 [ 3080 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.819633 [ 3059 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:31.917517 [ 3065 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.062707 [ 3107 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.146730 [ 3084 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.341780 [ 3116 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.343089 [ 3094 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.586580 [ 3113 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.763544 [ 3115 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.823017 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:32.920490 [ 3108 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.065722 [ 3140 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.150261 [ 3133 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.344555 [ 3126 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.345952 [ 3114 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.589437 [ 3158 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.766620 [ 3141 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.835564 [ 3142 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:33.923775 [ 3165 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.068103 [ 3145 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.153065 [ 3170 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.347244 [ 3209 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.348802 [ 3208 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.591887 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.769459 [ 2841 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.839388 [ 2920 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:34.926454 [ 2875 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.070379 [ 2884 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.155769 [ 2898 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.350248 [ 2915 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.351161 [ 2932 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.594590 [ 2952 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.772061 [ 2946 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.842398 [ 2970 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:35.929704 [ 2922 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.072978 [ 2936 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.158338 [ 2948 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.352762 [ 2958 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.353644 [ 2917 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.598030 [ 2950 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.781805 [ 2925 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.848059 [ 2973 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:36.932687 [ 3112 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.075925 [ 2965 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.160986 [ 2962 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.355916 [ 2960 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.356518 [ 2997 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.600412 [ 2987 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.784724 [ 2990 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.851363 [ 2984 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:37.936172 [ 2949 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.078696 [ 3028 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.163671 [ 3007 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.361545 [ 3102 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.365965 [ 3072 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.611446 [ 3183 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.796959 [ 3130 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.854472 [ 3240 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:38.940473 [ 3227 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.083701 [ 3301 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.165888 [ 3191 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.170339 [ 12800 ] {cf377d82-c1f4-487b-8ddc-79567ff2c0b5} 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.10521.altinitytest (altinity build)) (from [::1]:42556) (comment: 00938_fix_rwlock_segfault_long.sh) (in query: SELECT name FROM system.tables UNION ALL SELECT name FROM system.columns 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:37:39.258391 [ 12800 ] {cf377d82-c1f4-487b-8ddc-79567ff2c0b5} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:37:39.363712 [ 2902 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.373598 [ 2894 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.622089 [ 2885 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.799941 [ 2909 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.857203 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:39.944077 [ 2910 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:40.085967 [ 2907 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:40.185913 [ 2836 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:40.366294 [ 2841 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:40.376648 [ 2899 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:40.624859 [ 2891 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:40.802455 [ 2915 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:40.860025 [ 2932 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.002778 [ 2914 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.092642 [ 2931 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.189044 [ 2946 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.367441 [ 3445 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {85a939ff-1bdc-434a-abe3-c1f1ded4b10d::202510_1_184_52}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.378120 [ 2876 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.379245 [ 2941 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.627516 [ 2953 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.805232 [ 2934 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:41.862701 [ 2958 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.006441 [ 2927 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.097480 [ 2925 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.195951 [ 2971 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.380795 [ 2977 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.381696 [ 2957 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.630644 [ 2974 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.882475 [ 2959 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:42.883296 [ 2960 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.010050 [ 3004 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.100455 [ 2987 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.198626 [ 2949 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.383472 [ 2989 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.384358 [ 3028 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.633915 [ 3019 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.885797 [ 3025 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:43.886393 [ 3001 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.012680 [ 3023 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.104151 [ 2999 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.201635 [ 3021 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.386643 [ 2991 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.387355 [ 3032 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.640057 [ 3022 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.888834 [ 3054 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:44.889035 [ 3005 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.015256 [ 3026 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.112608 [ 3085 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.203940 [ 3050 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.389225 [ 3041 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.389734 [ 3057 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.643415 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.891402 [ 3056 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:45.899966 [ 3068 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.020681 [ 3090 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.115375 [ 3089 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.206282 [ 3082 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.392344 [ 3070 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.392980 [ 3049 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.646340 [ 3099 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.893884 [ 3107 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:46.902421 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.002798 [ 4168 ] {c399721f-0d8a-4fbd-8fdc-251c147257e0} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37922) (comment: 02947_non_post_request_should_be_readonly.sh) (in query: CREATE DATABASE non_post_request_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc9301 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000026dc69d8 5. ./build_docker/./src/Access/ContextAccess.cpp:756: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000026dd8fb9 6. ./build_docker/./src/Access/ContextAccess.cpp:792: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000026d9787c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000002852c844 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::InterpreterCreateQuery::execute() @ 0x00000000291c808f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:37:47.008725 [ 4168 ] {c399721f-0d8a-4fbd-8fdc-251c147257e0} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. For queries over HTTP, method GET implies readonly. You should use method POST for modifying queries. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc9301 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000026dc69d8 5. ./build_docker/./src/Access/ContextAccess.cpp:756: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000026dd8fb9 6. ./build_docker/./src/Access/ContextAccess.cpp:792: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000026d9787c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000002852c844 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::InterpreterCreateQuery::execute() @ 0x00000000291c808f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.023093 [ 3075 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.117747 [ 3102 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.125967 [ 16871 ] {ad97b0ac-28f6-4f5a-b43f-1dc7c2cd9be7} executeQuery: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37938) (comment: 02947_non_post_request_should_be_readonly.sh) (in query: CREATE DATABASE non_post_request_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc9301 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000026dc69d8 5. ./build_docker/./src/Access/ContextAccess.cpp:756: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000026dd8fb9 6. ./build_docker/./src/Access/ContextAccess.cpp:792: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000026d9787c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000002852c844 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::InterpreterCreateQuery::execute() @ 0x00000000291c808f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:37:47.133911 [ 16871 ] {ad97b0ac-28f6-4f5a-b43f-1dc7c2cd9be7} DynamicQueryHandler: Code: 164. DB::Exception: default: Cannot execute query in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: auto bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const::'lambda'(int, FormatStringHelperImpl::type...>, $T&&...)::operator()<>(int, FormatStringHelperImpl::type...>, $T&&...) const @ 0x0000000026dc9301 4. ./build_docker/./src/Access/ContextAccess.cpp:0: bool DB::ContextAccess::checkAccessImplHelper>>(std::shared_ptr const&, DB::AccessFlags, std::basic_string_view> const&) const @ 0x0000000026dc69d8 5. ./build_docker/./src/Access/ContextAccess.cpp:756: bool DB::ContextAccess::checkAccessImplHelper(std::shared_ptr const&, DB::AccessRightsElement const&) const @ 0x0000000026dd8fb9 6. ./build_docker/./src/Access/ContextAccess.cpp:792: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessRightsElements const&) const @ 0x0000000026d9787c 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkAccess(DB::AccessRightsElements const&) const @ 0x000000002852c844 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::InterpreterCreateQuery::execute() @ 0x00000000291c808f 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.209208 [ 3072 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.395795 [ 3116 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.396008 [ 3094 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.648915 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.896843 [ 3103 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:47.905733 [ 3117 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.026343 [ 3087 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.120863 [ 3105 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.215367 [ 3111 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.398477 [ 3127 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.399210 [ 3132 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.651856 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.899614 [ 3156 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:48.908647 [ 3126 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.041882 [ 3160 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.124022 [ 3152 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.225656 [ 3158 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.401538 [ 3151 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.402062 [ 3163 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.654561 [ 3164 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.902716 [ 3174 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:49.912410 [ 3161 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.046123 [ 3168 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.186739 [ 3166 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.230257 [ 3179 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.434169 [ 3150 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.435015 [ 3219 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.656651 [ 3184 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.904921 [ 3176 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:50.918127 [ 3204 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.048576 [ 3205 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.189996 [ 3215 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.234863 [ 3218 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.437165 [ 3172 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.437489 [ 3203 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.694726 [ 3216 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.907987 [ 3214 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:51.994683 [ 3230 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.051393 [ 3249 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.192848 [ 3254 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.237411 [ 3250 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.439872 [ 3227 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.530329 [ 3229 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.697340 [ 3242 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.910602 [ 3207 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:52.997273 [ 3223 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:53.053776 [ 3220 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:53.195385 [ 3233 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:53.241688 [ 3228 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:53.442427 [ 3232 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:53.533504 [ 3253 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:53.699743 [ 3248 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:53.912939 [ 3246 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.045007 [ 3279 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.056089 [ 3264 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.197995 [ 3305 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.244171 [ 3217 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.445081 [ 3269 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.536332 [ 3300 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.702524 [ 3307 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:54.915944 [ 3290 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.047948 [ 3299 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.062326 [ 3313 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.200925 [ 3311 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.246947 [ 3268 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.447415 [ 3317 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.539280 [ 3314 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.704965 [ 3302 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:55.935022 [ 3298 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.050325 [ 2847 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.066011 [ 3334 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.183302 [ 17626 ] {25e742c8-94cb-4f6f-8d60-7b75fb77106c} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36120) (comment: 01156_pcg_deserialization.sh) (in query: CREATE TABLE t (`n` UInt8, `a1` AggregateFunction(groupArraySample(1), UInt8)) ENGINE = MergeTree ORDER BY n SETTINGS index_granularity = 43355, min_bytes_for_wide_part = 1049580434, 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 = 137743248, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25015495, merge_max_block_size = 2312, 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 = 10342454322, index_granularity_bytes = 17417887, concurrent_part_removal_threshold = 22, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 89227, primary_key_compress_block_size = 36559), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:56.202099 [ 17626 ] {25e742c8-94cb-4f6f-8d60-7b75fb77106c} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:37:56.203386 [ 3292 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.250762 [ 3324 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.449884 [ 3331 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.541936 [ 3266 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.708063 [ 2850 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:56.938285 [ 3328 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.053136 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.071619 [ 2835 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.206113 [ 2872 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.253038 [ 2837 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.259329 [ 16871 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f870ba 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f84ca0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f83191 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f83764 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853e821 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000002853f411 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&) @ 0x000000002d076239 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.452580 [ 2877 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.544629 [ 2827 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.711065 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:57.944333 [ 2863 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.055440 [ 2864 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.074572 [ 3335 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.208765 [ 2855 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.255377 [ 2888 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.455748 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.547672 [ 2919 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.713429 [ 2897 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:58.946720 [ 2926 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.058563 [ 2900 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.077335 [ 2904 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.211470 [ 2844 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.257743 [ 2899 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.458028 [ 2870 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.550292 [ 2893 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.716076 [ 2874 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:37:59.949503 [ 2886 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.061052 [ 2935 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.079732 [ 2892 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.213885 [ 2914 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.260185 [ 2916 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.470767 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.555703 [ 2940 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.719205 [ 2941 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:00.952379 [ 2951 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.063229 [ 2945 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.081980 [ 2934 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.218148 [ 2958 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.262775 [ 2950 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.473335 [ 2966 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.558365 [ 2954 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.722175 [ 2967 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:01.960571 [ 2977 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.065653 [ 2981 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.085188 [ 2965 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.221051 [ 2974 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.266614 [ 2994 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.475883 [ 2960 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.561119 [ 2997 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.724458 [ 3002 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:02.962954 [ 2984 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.067881 [ 2949 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.087893 [ 2995 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.223414 [ 3008 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.269793 [ 3024 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.479026 [ 2975 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.564038 [ 3015 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.727315 [ 3021 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:03.965483 [ 3031 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.070336 [ 3032 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.090913 [ 3034 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.235660 [ 2983 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.273183 [ 3060 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.482366 [ 3026 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.567161 [ 3048 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.729615 [ 3016 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:04.968530 [ 3057 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.072896 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.093698 [ 3078 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.238776 [ 3063 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.277306 [ 3081 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.484566 [ 3107 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.569507 [ 3102 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.738133 [ 3116 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:05.970785 [ 3087 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.075773 [ 3073 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.096397 [ 3084 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.247541 [ 3111 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.280112 [ 3058 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.487522 [ 3109 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.572439 [ 3059 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.741331 [ 3096 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:06.795132 [ 16881 ] {3b18699e-78d3-456e-a5cc-bac0653d26ca} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36150) (comment: 02944_dynamically_change_filesystem_cache_size.sh) (in query: SELECT sum(size) FROM system.filesystem_cache WHERE state = 'DOWNLOADED'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:38:06.840904 [ 16881 ] {3b18699e-78d3-456e-a5cc-bac0653d26ca} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:38:06.973328 [ 3079 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.078542 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.098503 [ 3132 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.250698 [ 3088 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.282969 [ 3108 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.496350 [ 3118 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.577901 [ 3133 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.744474 [ 3129 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:07.976167 [ 3147 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.081053 [ 3121 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.113712 [ 3142 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.253131 [ 3155 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.284918 [ 3123 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.499766 [ 3161 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.595149 [ 3185 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.747414 [ 3183 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:08.982678 [ 3143 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.083281 [ 3181 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.116414 [ 3219 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.263664 [ 3206 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.287353 [ 3175 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.502868 [ 3186 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.600208 [ 3201 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.749517 [ 3204 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:09.985300 [ 3200 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.087953 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.119171 [ 3218 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.266410 [ 3203 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.290085 [ 3240 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.505944 [ 3226 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.603229 [ 3244 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.752326 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:10.997316 [ 3249 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:11.090996 [ 3250 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:11.121725 [ 3211 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:11.269196 [ 3227 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:11.294474 [ 3229 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:11.532759 [ 3238 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:11.605861 [ 3220 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:11.754534 [ 3208 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.001599 [ 3195 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.083382 [ 17626 ] {bbb5ba49-3fcb-4fa2-bd51-f671e486325a} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:39230) (comment: 01156_pcg_deserialization.sh) (in query: CREATE TABLE t (`n` UInt8, `a1` AggregateFunction(groupUniqArray(1), UInt8)) ENGINE = MergeTree ORDER BY n SETTINGS index_granularity = 43355, min_bytes_for_wide_part = 1049580434, 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 = 137743248, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 25015495, merge_max_block_size = 2312, 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 = 10342454322, index_granularity_bytes = 17417887, concurrent_part_removal_threshold = 22, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 89227, primary_key_compress_block_size = 36559), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:12.094491 [ 17626 ] {bbb5ba49-3fcb-4fa2-bd51-f671e486325a} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:12.095425 [ 3213 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.125063 [ 3256 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.272252 [ 3232 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.297831 [ 3245 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.535639 [ 3273 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.609062 [ 3246 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:12.757494 [ 3272 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.005058 [ 3276 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.098633 [ 3305 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.168763 [ 3271 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.275365 [ 3257 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.304633 [ 3269 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.538988 [ 3301 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.634676 [ 3278 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:13.760456 [ 3307 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.009606 [ 3321 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.101813 [ 3311 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.171952 [ 3293 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.278484 [ 3317 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.307610 [ 3329 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.542018 [ 3315 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.642157 [ 3298 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:14.763230 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.013243 [ 3326 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.117409 [ 3292 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.177059 [ 3324 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.280703 [ 2832 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.310565 [ 2845 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.552324 [ 2825 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.645135 [ 2838 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:15.771130 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.017289 [ 3312 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.125284 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.189441 [ 2867 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.284614 [ 2856 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.313675 [ 2872 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.556425 [ 2877 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.648451 [ 2881 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:16.778323 [ 2834 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.019955 [ 2882 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.134262 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.192736 [ 2855 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.287633 [ 2888 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.319655 [ 2902 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.559139 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.651464 [ 2879 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:17.781019 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.023588 [ 2908 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.136926 [ 2943 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.208177 [ 2900 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.290127 [ 2836 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.322274 [ 2844 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.562063 [ 2924 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.655985 [ 2870 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.783788 [ 2874 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:18.859257 [ 3448 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_311_326_3}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.025863 [ 2942 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.139333 [ 2952 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.212243 [ 2940 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.292494 [ 2876 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.325105 [ 2921 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.564750 [ 2934 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.658932 [ 2933 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:19.786418 [ 2953 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.028660 [ 2986 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.141912 [ 2973 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.215394 [ 2967 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.295209 [ 2929 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.328571 [ 2977 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.570550 [ 2962 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.661868 [ 2969 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:20.788902 [ 2988 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.031483 [ 2964 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.144763 [ 2974 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.218274 [ 2978 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.298011 [ 2994 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.331977 [ 2993 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.574723 [ 2996 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.664811 [ 3002 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:21.792419 [ 2984 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.034296 [ 2995 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.147079 [ 2998 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.220615 [ 3028 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.300578 [ 3008 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.336057 [ 3024 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.358151 [ 16551 ] {7cc4325b-301d-4004-b9ab-01dee19d3dfc} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.005328986 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36712) (comment: 01603_read_with_backoff_bug.sql) (in query: INSERT INTO t SELECT number, if(number < (8129 * 1024), arrayStringConcat(arrayMap(x -> toString(x), range(number % 128)), ' '), '') FROM numbers_mt((8129 * 1024) * 3) settings max_insert_threads=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 7. ./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*) @ 0x000000002d356ec7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:38:22.577179 [ 3007 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.691277 [ 3025 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:22.738839 [ 16551 ] {7cc4325b-301d-4004-b9ab-01dee19d3dfc} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.005328986 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 7. ./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*) @ 0x000000002d356ec7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:38:22.796343 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.036832 [ 3037 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.153604 [ 2991 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.223489 [ 3034 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.300882 [ 3047 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.303439 [ 3045 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.338824 [ 3046 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.579500 [ 3044 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.693957 [ 3012 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:23.799462 [ 3041 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.039510 [ 3078 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.156533 [ 3069 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.225876 [ 3081 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.306573 [ 3090 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.343352 [ 3082 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.582983 [ 3102 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.697248 [ 3116 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:24.801781 [ 3117 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.042023 [ 3083 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.161615 [ 3111 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.230078 [ 3091 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.308928 [ 3065 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.345808 [ 3092 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.396735 [ 4168 ] {00f861c9-1da8-4509-be88-c5dfe82e7794} 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.10521.altinitytest (altinity build)) (from [::1]:40984) (comment: 02555_davengers_rename_chain.sh) (in query: CREATE TABLE wrong_metadata( a UInt64, b UInt64, c UInt64 ) ENGINE ReplicatedMergeTree('/test/{database}/tables/wrong_metadata', '1') ORDER BY tuple() SETTINGS min_bytes_for_wide_part = 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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) @ 0x000000002ba1f4b4 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&) @ 0x000000002cbb5a1b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac3df 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:38:25.404081 [ 4168 ] {00f861c9-1da8-4509-be88-c5dfe82e7794} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c467596 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) @ 0x000000002ba1f4b4 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&) @ 0x000000002cbb5a1b 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbac3df 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 @ 0x000000002b782bf3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291be014 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:38:25.586684 [ 3079 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.700430 [ 3115 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.805013 [ 3088 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:25.813044 [ 17626 ] {a0792fb8-451c-4134-8eb4-f48b25abe45f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52406) (comment: 01747_join_view_filter_dictionary.sql) (in query: drop view rates01747;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:38:25.822966 [ 17626 ] {a0792fb8-451c-4134-8eb4-f48b25abe45f} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260eb330 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f6f2f 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291f3f25 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f2628 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:38:26.046824 [ 3139 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.154358 [ 17626 ] {af69d390-53a9-43fe-90f5-4d2d100a7c53} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:40994) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:26.159853 [ 17626 ] {af69d390-53a9-43fe-90f5-4d2d100a7c53} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:26.163872 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.232484 [ 3129 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.314309 [ 3126 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.348037 [ 3114 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.588995 [ 3138 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.703080 [ 3145 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.807657 [ 3137 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:26.839898 [ 4168 ] {1db43ec8-6d15-4b3d-b06a-c3aad9b2051a} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41026) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:26.853493 [ 4168 ] {1db43ec8-6d15-4b3d-b06a-c3aad9b2051a} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:27.049377 [ 3170 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:27.166091 [ 3174 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:27.235233 [ 3185 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:27.316747 [ 3187 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:27.351129 [ 3182 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:27.521943 [ 17626 ] {fad0711d-12e0-4d6e-adb8-c3ef7ac4b3fd} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41030) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:27.576556 [ 17626 ] {fad0711d-12e0-4d6e-adb8-c3ef7ac4b3fd} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:27.591775 [ 3180 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:27.706639 [ 3110 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:27.810182 [ 3219 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.051470 [ 3190 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.168324 [ 3186 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.225191 [ 17626 ] {9a1ab028-5161-4689-bd40-606c9141c4cc} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41040) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:28.238646 [ 17626 ] {9a1ab028-5161-4689-bd40-606c9141c4cc} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:28.242993 [ 3201 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.319015 [ 3204 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.356011 [ 3193 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.596709 [ 3215 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.709718 [ 3130 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.813778 [ 3240 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:28.975115 [ 4168 ] {2c658b06-7158-414f-ab17-87b4e072b793} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41054) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:28.989332 [ 4168 ] {2c658b06-7158-414f-ab17-87b4e072b793} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:29.053844 [ 3230 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:29.171291 [ 3254 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:29.249114 [ 3225 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:29.322057 [ 3252 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:29.358758 [ 3260 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:29.599863 [ 3281 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:29.714385 [ 3210 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:29.752668 [ 4168 ] {cefa5fd3-a310-4d3a-ad73-2be448f90419} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41062) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:29.764794 [ 4168 ] {cefa5fd3-a310-4d3a-ad73-2be448f90419} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:29.818479 [ 3223 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.057117 [ 3256 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.163361 [ 12800 ] {02df30e6-d9ff-477e-a203-9b255f882c29} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52426) (comment: 02944_dynamically_change_filesystem_cache_size.sh) (in query: SELECT count() FROM system.filesystem_cache WHERE state = 'DOWNLOADED'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:38:30.166031 [ 12800 ] {02df30e6-d9ff-477e-a203-9b255f882c29} TCPHandler: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:38:30.173819 [ 3273 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.251702 [ 3291 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.324865 [ 3295 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.361094 [ 3276 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.464337 [ 4168 ] {5f89ebbd-6e67-49b7-aee4-3a2b79c75ca3} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41078) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:30.471763 [ 4168 ] {5f89ebbd-6e67-49b7-aee4-3a2b79c75ca3} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:30.605246 [ 3301 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.716811 [ 3286 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:30.826439 [ 3285 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.059384 [ 3239 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.179160 [ 3248 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.215745 [ 4168 ] {30b49e6f-685b-4be7-b39a-09e8f1afeaa2} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41090) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:31.234419 [ 4168 ] {30b49e6f-685b-4be7-b39a-09e8f1afeaa2} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:31.255713 [ 3279 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.327790 [ 3255 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.363622 [ 3199 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.609092 [ 3294 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.719967 [ 3297 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:31.829383 [ 3308 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.001305 [ 16551 ] {021275e0-b464-45c8-8c70-5ecdfdbf807b} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41100) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:32.018943 [ 16551 ] {021275e0-b464-45c8-8c70-5ecdfdbf807b} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:32.062256 [ 3293 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.184249 [ 3317 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.258320 [ 3314 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.285203 [ 4168 ] {0b372b81-b352-4e4a-a811-b152dc991852} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41096) (comment: 02136_scalar_subquery_metrics.sql) (in query: SELECT '#02136_scalar_subquery_2', (SELECT max(number) FROM numbers(1000)) as n, (SELECT min(number) FROM numbers(1000)) as n2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002837b3e0 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836ba2f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:38:32.296271 [ 4168 ] {0b372b81-b352-4e4a-a811-b152dc991852} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002837b3e0 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836ba2f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 28. asan_thread_start(void*) @ 0x000000000aa45059 29. ? @ 0x00007f2f94fabac3 30. ? @ 0x00007f2f9503d850 2025.10.15 20:38:32.330422 [ 3313 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.366182 [ 3319 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.612176 [ 3263 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.723668 [ 3298 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.833204 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:32.889497 [ 4168 ] {fd6dd54f-fdfd-470e-a5c6-120fa5f2cb83} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41110) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:32.926964 [ 4168 ] {fd6dd54f-fdfd-470e-a5c6-120fa5f2cb83} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:33.065453 [ 2828 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:33.186689 [ 3324 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:33.260358 [ 3287 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:33.333000 [ 2826 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:33.368983 [ 3191 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:33.615232 [ 2825 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:33.679035 [ 16551 ] {9574da9a-79b2-45b0-8a9c-a0f4b92d0ead} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41120) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:33.685370 [ 16551 ] {9574da9a-79b2-45b0-8a9c-a0f4b92d0ead} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:33.726648 [ 3325 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:33.845131 [ 3312 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.068432 [ 2872 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.188801 [ 2837 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.264470 [ 2877 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.320764 [ 4168 ] {05533f82-afac-4180-8753-c5a22fb953a9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41114) (comment: 02833_array_join_columns.sql) (in query: select * from v4test_array_joins array join columns('^arr') where match(arr_4,'a') and id < 100 order by id format Null settings optimize_read_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:34.335670 [ 2843 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.338413 [ 4168 ] {05533f82-afac-4180-8753-c5a22fb953a9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=767, jobs=743). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:34.371563 [ 2862 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.455807 [ 16551 ] {5b1a06b9-9069-48d4-bf02-fa08fa0fccfa} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41124) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:34.459742 [ 16551 ] {5b1a06b9-9069-48d4-bf02-fa08fa0fccfa} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:34.618138 [ 2861 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.729616 [ 2880 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:34.848162 [ 3335 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.071056 [ 2901 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.191899 [ 2879 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.268971 [ 2909 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.338465 [ 2928 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.374462 [ 2923 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.380434 [ 4168 ] {e7f428ea-6235-4cf7-a2a6-34fafcc305b1} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36682) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:35.385147 [ 4168 ] {e7f428ea-6235-4cf7-a2a6-34fafcc305b1} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:35.622609 [ 2904 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.627878 [ 16551 ] {caef691d-0039-491d-9a84-891fcfde09e2} executeQuery: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36696) (comment: 02477_projection_materialize_and_zero_copy.sql) (in query: CREATE TABLE t (`c1` Int64, `c2` String, `c3` DateTime, `c4` Int8, `c5` String, `c6` String, `c7` String, `c8` String, `c9` String, `c10` String, `c11` String, `c12` String, `c13` Int8, `c14` Int64, `c15` String, `c16` String, `c17` String, `c18` Int64, `c19` Int64, `c20` Int64) ENGINE = ReplicatedMergeTree('/clickhouse/test/{database}/test_02477', '1') ORDER BY c18 SETTINGS allow_remote_fs_zero_copy_replication = 1, 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 = 0, compact_parts_max_bytes_to_buffer = 388087673, compact_parts_max_granules_to_buffer = 229, compact_parts_merge_max_bytes_to_prefetch_part = 5096078, merge_max_block_size = 8547, 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 = 43, min_merge_bytes_to_use_direct_io = 10737418240, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 85840, primary_key_compress_block_size = 56353), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:35.632473 [ 16551 ] {caef691d-0039-491d-9a84-891fcfde09e2} TCPHandler: Code: 57. DB::Exception: Table test_1.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:35.732407 [ 2836 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:35.850679 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.074069 [ 2920 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.161379 [ 4168 ] {9328fd29-cc92-4c3a-9d8f-357e59ae9a61} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36704) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:36.169703 [ 4168 ] {9328fd29-cc92-4c3a-9d8f-357e59ae9a61} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:36.194292 [ 2878 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.271446 [ 2891 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.341144 [ 2889 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.380921 [ 2930 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.625348 [ 2914 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.735255 [ 2952 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:36.853789 [ 2866 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.029262 [ 4168 ] {880f36ed-39ae-4aa4-9a2f-fbfb05521040} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36726) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:37.035543 [ 4168 ] {880f36ed-39ae-4aa4-9a2f-fbfb05521040} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:37.079722 [ 2918 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.199192 [ 2936 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.273514 [ 2951 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.348116 [ 2937 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.383444 [ 2941 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.628636 [ 2986 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.737853 [ 2929 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.850867 [ 16551 ] {442d70fd-31b2-4b8b-98ad-5bc5bb834fb2} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36736) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:37.857473 [ 2965 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:37.858383 [ 16551 ] {442d70fd-31b2-4b8b-98ad-5bc5bb834fb2} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:38.082278 [ 2993 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:38.201995 [ 2971 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:38.276643 [ 2945 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:38.285349 [ 16881 ] {7d38219d-add8-4d34-a5cf-afd6b8b4da7a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:41084) (comment: 02944_dynamically_change_filesystem_cache_size.sh) (in query: SELECT sum(size) FROM system.filesystem_cache WHERE state = 'DOWNLOADED'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:38:38.297367 [ 16881 ] {7d38219d-add8-4d34-a5cf-afd6b8b4da7a} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 2025.10.15 20:38:38.388272 [ 2958 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:38.429069 [ 2956 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:38.631568 [ 2944 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:38.646820 [ 4168 ] {4eb106e3-8409-4e6e-9938-0afdff16ef24} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36748) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:38.675720 [ 4168 ] {4eb106e3-8409-4e6e-9938-0afdff16ef24} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:38.746935 [ 3004 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:38.870493 [ 2963 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.084948 [ 2979 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.204928 [ 2990 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.279858 [ 2995 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.391184 [ 3028 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.449763 [ 16551 ] {a30220b9-1ec2-427a-bd64-78a357ec9df0} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36780) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:39.468929 [ 16551 ] {a30220b9-1ec2-427a-bd64-78a357ec9df0} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:39.486131 [ 2949 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.633718 [ 2975 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.749423 [ 3000 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.873703 [ 3043 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.888757 [ 4168 ] {df73ffc9-97b8-418d-9520-71b5c117684d} DB::ConcurrentHashJoin::ConcurrentHashJoin(ContextPtr, std::shared_ptr, size_t, const Block &, const StatsCollectingParams &, bool): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287b12f0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294aaf34 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000294697dd 13. ./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&) @ 0x000000002946217d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 16. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::Planner::buildPlanForUnionNode() @ 0x000000002942bbc9 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9b4 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 27. asan_thread_start(void*) @ 0x000000000aa45059 28. ? @ 0x00007f2f94fabac3 29. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:39.916929 [ 4168 ] {df73ffc9-97b8-418d-9520-71b5c117684d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36770) (comment: 01416_join_totals_header_bug.sql) (in query: SELECT * FROM ( SELECT common.key, common.value, trees.name, trees.name2 FROM ( SELECT * FROM tableCommon ) as common INNER JOIN ( SELECT * FROM tableTrees ) trees ON (common.key = trees.key) ) UNION ALL ( SELECT common.key, common.value, null as name, null as name2 FROM ( SELECT * FROM tableCommon ) as common INNER JOIN ( SELECT * FROM tableFlowers ) flowers ON (common.key = flowers.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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287b12f0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294aaf34 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000294697dd 13. ./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&) @ 0x000000002946217d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 16. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::Planner::buildPlanForUnionNode() @ 0x000000002942bbc9 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9b4 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 27. asan_thread_start(void*) @ 0x000000000aa45059 28. ? @ 0x00007f2f94fabac3 29. ? @ 0x00007f2f9503d850 2025.10.15 20:38:39.934344 [ 4168 ] {df73ffc9-97b8-418d-9520-71b5c117684d} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af84f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000287b12f0 7. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::chooseJoinAlgorithm(std::shared_ptr&, std::shared_ptr const&, DB::Block const&, DB::Block const&, std::shared_ptr const&) @ 0x00000000294aaf34 8. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1466: DB::(anonymous namespace)::buildQueryPlanForJoinNode(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002947aeaf 9. ./build_docker/./src/Planner/PlannerJoinTree.cpp:0: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x0000000029463954 10. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 11. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 12. ./contrib/llvm-project/libcxx/include/__hash_table:1743: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000294697dd 13. ./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&) @ 0x000000002946217d 14. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029431166 15. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9bb 16. ./contrib/llvm-project/libcxx/include/__tree:1124: DB::Planner::buildPlanForUnionNode() @ 0x000000002942bbc9 17. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000002942a9b4 18. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x0000000029425d12 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3bcde 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 27. asan_thread_start(void*) @ 0x000000000aa45059 28. ? @ 0x00007f2f94fabac3 29. ? @ 0x00007f2f9503d850 2025.10.15 20:38:40.087054 [ 2999 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:40.167359 [ 4168 ] {330fdc0f-cf34-4a43-b4e7-70f9274dfc1f} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36790) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:40.182405 [ 4168 ] {330fdc0f-cf34-4a43-b4e7-70f9274dfc1f} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:40.207605 [ 3035 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:40.371099 [ 3033 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:40.394386 [ 2991 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:40.488606 [ 3047 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:40.638690 [ 3022 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:40.751566 [ 3052 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:40.876622 [ 3054 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.027054 [ 16551 ] {873b12dd-875a-4263-9dfc-3e53f762f4c5} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36798) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:41.043400 [ 16551 ] {873b12dd-875a-4263-9dfc-3e53f762f4c5} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:41.089610 [ 3085 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.209969 [ 3020 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.373212 [ 3012 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.379783 [ 4168 ] {ccb03cb5-faa8-434a-8a2e-9c7c4c8ef38c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36796) (comment: 02350_views_max_insert_threads.sql) (in query: insert into t select * from numbers_mt(10e6) settings max_threads = 16, max_insert_threads=16, max_block_size=100000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d356ec7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:38:41.396795 [ 3041 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.401086 [ 4168 ] {ccb03cb5-faa8-434a-8a2e-9c7c4c8ef38c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=12, jobs=12). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d356ec7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f2f94fabac3 14. ? @ 0x00007f2f9503d850 2025.10.15 20:38:41.491370 [ 3064 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.641404 [ 3078 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.754515 [ 3056 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:41.816842 [ 4168 ] {890b0dab-0fd6-4096-813b-a5d66c867ee7} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36806) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:41.826941 [ 4168 ] {890b0dab-0fd6-4096-813b-a5d66c867ee7} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:41.879905 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.093857 [ 3061 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.212392 [ 3116 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.376116 [ 3093 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.399468 [ 3117 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.493979 [ 3105 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.633816 [ 4168 ] {3bb790ab-bb29-4548-8fb7-9456c40f5ec9} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36812) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:42.654527 [ 4168 ] {3bb790ab-bb29-4548-8fb7-9456c40f5ec9} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:42.684377 [ 3091 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.760372 [ 3065 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:42.882709 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.114376 [ 3109 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.215287 [ 3067 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.378754 [ 3079 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.402254 [ 3106 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.403320 [ 4168 ] {83aa42b5-d704-4fba-9e58-f47353d0fa1b} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36824) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:43.415425 [ 4168 ] {83aa42b5-d704-4fba-9e58-f47353d0fa1b} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:43.496847 [ 3088 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.687020 [ 3128 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.763089 [ 3140 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:43.889448 [ 3118 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.117034 [ 3133 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.219001 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.234296 [ 16551 ] {7f8f26ce-3fd3-4788-b7bb-ad7f767a6e1f} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36840) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:44.279566 [ 16551 ] {7f8f26ce-3fd3-4788-b7bb-ad7f767a6e1f} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:44.382475 [ 3104 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.405564 [ 3120 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.500910 [ 3129 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.689742 [ 3126 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.765657 [ 3100 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:44.892434 [ 3114 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.091151 [ 16551 ] {e621c41d-46c8-41fe-9013-64c2d63a0ccf} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:36850) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:45.116993 [ 16551 ] {e621c41d-46c8-41fe-9013-64c2d63a0ccf} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:45.120906 [ 3147 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.222764 [ 3152 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.402361 [ 3142 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.411988 [ 3122 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.503676 [ 3151 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.713351 [ 16551 ] {20051482-b55b-4462-a416-b2aa09b89e0b} executeQuery: Code: 86. DB::Exception: Received error from remote server /test%2Fa.tsv. HTTP status code: 403 Forbidden, body: AccessDeniedAccess Denied.test%2Fa.tsv/test/a.tsv186EBE1A8A26FAF47dc7eb22d3288ec80374614e9088e31d3668a6922ead55932dd2a8e56373820f: (while reading header): (in file/uri /test%2Fa.tsv): While executing TabSeparatedRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44814) (comment: 02833_url_without_path_encoding.sh) (in query: select count() from url('http://localhost:11111/test%2Fa.tsv') settings enable_url_encoding=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3befac 4. ./src/Common/Exception.h:43: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3bf2f4 5. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000001b3becf1 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001b536613 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001b536b39 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001b537d39 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001b53d4d8 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b5325f1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001b53a4a3 12. DB::ReadBuffer::next() @ 0x000000000b52aaeb 13. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000001aeff79c 14. DB::ReadBuffer::next() @ 0x000000000b52aaeb 15. ./src/IO/ReadHelpers.h:1868: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000002d4c7394 16. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47defc 17. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 19. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 24. ./build_docker/./src/Storages/StorageURL.cpp:426: DB::StorageURLSource::generate() @ 0x000000002bd8087d 25. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 2025.10.15 20:38:45.729168 [ 16551 ] {20051482-b55b-4462-a416-b2aa09b89e0b} TCPHandler: Code: 86. DB::Exception: Received error from remote server /test%2Fa.tsv. HTTP status code: 403 Forbidden, body: AccessDeniedAccess Denied.test%2Fa.tsv/test/a.tsv186EBE1A8A26FAF47dc7eb22d3288ec80374614e9088e31d3668a6922ead55932dd2a8e56373820f: (while reading header): (in file/uri /test%2Fa.tsv): While executing TabSeparatedRowInputFormat: While executing URL. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::HTTPException::makeExceptionMessage(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3befac 4. ./src/Common/Exception.h:43: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000001b3bf2f4 5. ./build_docker/./src/IO/HTTPCommon.cpp:91: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000001b3becf1 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001b536613 7. ./build_docker/./src/IO/ReadWriteBufferFromHTTP.cpp:0: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001b536b39 8. ./contrib/llvm-project/libcxx/include/optional:344: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001b537d39 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000001b53d4d8 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b5325f1 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001b53a4a3 12. DB::ReadBuffer::next() @ 0x000000000b52aaeb 13. ./build_docker/./src/IO/PeekableReadBuffer.cpp:0: DB::PeekableReadBuffer::nextImpl() @ 0x000000001aeff79c 14. DB::ReadBuffer::next() @ 0x000000000b52aaeb 15. ./src/IO/ReadHelpers.h:1868: DB::RowInputFormatWithNamesAndTypes::readPrefix() @ 0x000000002d4c7394 16. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d47defc 17. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d38b226 18. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 19. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 20. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 21. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d359b12 23. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d37ec76 24. ./build_docker/./src/Storages/StorageURL.cpp:426: DB::StorageURLSource::generate() @ 0x000000002bd8087d 25. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d33a6f8 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 2025.10.15 20:38:45.764109 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.783516 [ 3137 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.895614 [ 3164 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:45.900316 [ 17626 ] {d5e13767-2fb0-451e-8649-a313efa5d8f6} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44820) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:45.909524 [ 17626 ] {d5e13767-2fb0-451e-8649-a313efa5d8f6} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:46.123363 [ 3154 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:46.224937 [ 3168 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:46.404482 [ 3179 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:46.419764 [ 3135 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:46.506043 [ 3143 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:46.577834 [ 12800 ] {d43ac57d-a6ed-431a-9d97-b0d982de0fde} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44846) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:46.591086 [ 12800 ] {d43ac57d-a6ed-431a-9d97-b0d982de0fde} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:46.767009 [ 3134 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:46.788834 [ 3206 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:46.898007 [ 3175 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.130546 [ 3149 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.227308 [ 3201 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.366955 [ 12800 ] {50480f1a-efe2-4b1e-9aa3-bd4575ddda03} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44850) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:47.401572 [ 12800 ] {50480f1a-efe2-4b1e-9aa3-bd4575ddda03} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:47.406809 [ 3172 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.422184 [ 3130 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.508807 [ 3235 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.769706 [ 3241 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.791874 [ 3216 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:47.900409 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.135859 [ 3236 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.229609 [ 3250 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.244885 [ 12800 ] {074222ff-9c57-408d-a8d6-f243cbbd3abe} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44866) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:48.260069 [ 12800 ] {074222ff-9c57-408d-a8d6-f243cbbd3abe} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:48.409865 [ 3252 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.427529 [ 3260 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.515589 [ 3258 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.772832 [ 3210 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.794054 [ 3209 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.902806 [ 3265 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:48.976330 [ 12800 ] {a30c00ff-4f59-49fb-b64b-9b3997646d24} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44874) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:48.992278 [ 12800 ] {a30c00ff-4f59-49fb-b64b-9b3997646d24} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:49.138547 [ 3273 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:49.266091 [ 3195 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:49.412984 [ 3276 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:49.429966 [ 3305 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:49.518569 [ 3301 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:49.776217 [ 3286 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:49.776761 [ 12800 ] {b9910190-cb95-45d1-b8d4-7e1b802c305c} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44878) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:49.787676 [ 12800 ] {b9910190-cb95-45d1-b8d4-7e1b802c305c} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:49.796881 [ 3285 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:49.909525 [ 3264 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.141156 [ 3274 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.268906 [ 3297 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.421303 [ 3306 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.434671 [ 3321 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.524666 [ 3261 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.566411 [ 16871 ] {7dbb307e-f216-4200-8880-0db7cd7f3421} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44910) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:50.579110 [ 16871 ] {7dbb307e-f216-4200-8880-0db7cd7f3421} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:50.779445 [ 3329 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.799735 [ 3304 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:50.913854 [ 3319 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.143602 [ 3298 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.271560 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.364963 [ 16871 ] {dafb0b36-bd8a-4cf5-b780-30e65ce98ede} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44932) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:51.375018 [ 16871 ] {dafb0b36-bd8a-4cf5-b780-30e65ce98ede} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:51.476800 [ 3330 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.477484 [ 2839 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.527486 [ 3326 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.782703 [ 2823 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.802720 [ 3324 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:51.916578 [ 3310 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.146263 [ 2852 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.163291 [ 16871 ] {442159aa-5b43-4adb-afd3-21bbf09ae7b5} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44964) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:52.182841 [ 16871 ] {442159aa-5b43-4adb-afd3-21bbf09ae7b5} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:52.273780 [ 2849 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.479310 [ 3309 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.479655 [ 2830 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.532483 [ 3328 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.785212 [ 2824 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.804933 [ 3332 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.923173 [ 2857 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:52.975021 [ 12800 ] {c46c0084-b3e5-4985-a60d-8599c5a634bb} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44984) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:52.995689 [ 12800 ] {c46c0084-b3e5-4985-a60d-8599c5a634bb} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:53.149717 [ 2877 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:53.275955 [ 2860 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:53.481858 [ 2867 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:53.482575 [ 2862 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:53.534835 [ 2871 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:53.772147 [ 12800 ] {eb13bb68-7c27-4334-874d-a94f2c254a9d} executeQuery: Code: 47. DB::Exception: Unknown expression identifier '_column0' in scope SELECT *, _column0 FROM s3('http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet') LIMIT 10. Maybe you meant: ['column0']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44992) (comment: 03203_hive_style_partitioning.sh) (in query: SELECT *, _column0 FROM s3('http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet') LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x00000000283ca1d5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836db54 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:38:53.787856 [ 2864 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:53.794569 [ 16881 ] {57cf6c15-042f-479a-88ba-848310940d93} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:44998) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:53.794533 [ 12800 ] {eb13bb68-7c27-4334-874d-a94f2c254a9d} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier '_column0' in scope SELECT *, _column0 FROM s3('http://localhost:11111/test/hive_partitioning/column0=Elizabeth/sample.parquet') LIMIT 10. Maybe you meant: ['column0']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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&&) @ 0x00000000283ca1d5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836db54 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 23. asan_thread_start(void*) @ 0x000000000aa45059 24. ? @ 0x00007f2f94fabac3 25. ? @ 0x00007f2f9503d850 2025.10.15 20:38:53.802856 [ 16881 ] {57cf6c15-042f-479a-88ba-848310940d93} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:53.807766 [ 2896 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:53.935043 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.152996 [ 2887 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.278997 [ 2895 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.485046 [ 2908 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.485910 [ 2897 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.538148 [ 2919 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.616270 [ 12800 ] {cb8b928d-373e-4445-872a-802a1ee0c370} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:45006) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:54.636325 [ 12800 ] {cb8b928d-373e-4445-872a-802a1ee0c370} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:54.793774 [ 2910 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.818679 [ 2926 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:54.938768 [ 2906 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.155926 [ 2878 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.287047 [ 2930 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.349938 [ 16881 ] {c262c023-090d-43e8-974b-d02931c63c95} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43096) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:55.385228 [ 16881 ] {c262c023-090d-43e8-974b-d02931c63c95} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:55.503429 [ 2914 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.503343 [ 2942 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.540955 [ 2952 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.796719 [ 2931 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.821895 [ 2829 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:55.940805 [ 2940 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.067478 [ 16881 ] {ba8c6a4f-eb53-47b1-b059-70356c055b82} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43102) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:56.089535 [ 16881 ] {ba8c6a4f-eb53-47b1-b059-70356c055b82} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:56.158108 [ 2892 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.289351 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.506564 [ 2957 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.506753 [ 2965 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.543632 [ 2969 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.791735 [ 16881 ] {20dff5f9-0103-4bb7-bdd8-6c1b0ef370cf} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43116) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:56.803560 [ 2974 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.818824 [ 16881 ] {20dff5f9-0103-4bb7-bdd8-6c1b0ef370cf} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:56.824011 [ 2994 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:56.943625 [ 2961 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.160061 [ 2981 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.297663 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.511292 [ 2997 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.512863 [ 2996 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.536827 [ 4168 ] {9208077d-464d-4adf-a84b-89276a809265} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43132) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:57.549298 [ 4168 ] {9208077d-464d-4adf-a84b-89276a809265} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:57.550896 [ 3004 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.806049 [ 2984 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.826794 [ 2995 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:57.947275 [ 3013 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.162291 [ 16881 ] {c48c1a25-9291-4ff4-8800-e60bcca8c65e} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43168) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:58.162553 [ 3015 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.168440 [ 16881 ] {c48c1a25-9291-4ff4-8800-e60bcca8c65e} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:58.300573 [ 3029 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.363488 [ 17626 ] {55b3d62b-a873-4a9f-9b93-df3bfba412c9} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43146) (comment: 01666_gcd_ubsan.sql) (in query: -- { echo } SELECT gcd(9223372036854775807, -9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000fe36357 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000fed77f0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84b4c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.367664 [ 17626 ] {55b3d62b-a873-4a9f-9b93-df3bfba412c9} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000fe36357 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000fed77f0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84b4c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.409485 [ 17626 ] {c4d4f041-bc35-4fd7-a989-813af64a4e0c} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43146) (comment: 01666_gcd_ubsan.sql) (in query: SELECT gcd(9223372036854775808, -9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000fe36357 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000fed77f0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84b4c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.419500 [ 17626 ] {c4d4f041-bc35-4fd7-a989-813af64a4e0c} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000fe36357 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000fed77f0 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84b4c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.514296 [ 3037 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.515498 [ 3027 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.553512 [ 3033 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.732122 [ 17626 ] {565048a0-f86a-4df5-8255-9b2585083739} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43146) (comment: 01666_gcd_ubsan.sql) (in query: SELECT gcd(-9223372036854775808, 9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000fe62df7 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ff3e168 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84fcc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.736551 [ 17626 ] {565048a0-f86a-4df5-8255-9b2585083739} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000fe62df7 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ff3e168 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84fcc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.810623 [ 3054 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.813279 [ 17626 ] {0a00a4a7-4a04-45af-a81e-6d6a94ec9c23} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43146) (comment: 01666_gcd_ubsan.sql) (in query: SELECT gcd(-9223372036854775807, 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000fe62df7 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ff3e168 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84fcc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.829768 [ 3030 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:58.830021 [ 17626 ] {0a00a4a7-4a04-45af-a81e-6d6a94ec9c23} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000fe62df7 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ff3e168 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84fcc 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:58.949614 [ 3048 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:59.031909 [ 16881 ] {a70363cf-63ef-41b5-9d3e-3cc5863206de} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43180) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:59.045283 [ 16881 ] {a70363cf-63ef-41b5-9d3e-3cc5863206de} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:59.137848 [ 17626 ] {8bc858ed-389d-4664-bad0-1377d89f28e8} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -1). (DECIMAL_OVERFLOW) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43146) (comment: 01666_gcd_ubsan.sql) (in query: SELECT gcd(9223372036854775808, -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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::GCDImpl::NameGCD>::apply(unsigned long, DB::(anonymous namespace)) @ 0x000000000fe34d52 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000fed4b29 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84b4c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:59.142813 [ 17626 ] {8bc858ed-389d-4664-bad0-1377d89f28e8} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -1). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ffae926 4. long DB::GCDLCMImpl, DB::(anonymous namespace)::GCDImpl::NameGCD>::apply(unsigned long, DB::(anonymous namespace)) @ 0x000000000fe34d52 5. _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000fed4b29 6. DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000fe84b4c 7. DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe80fd0 8. DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000fe7ea09 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa8e635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacb1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000cccecfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd065c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd4030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839de4f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 2025.10.15 20:38:59.164901 [ 3062 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:59.303624 [ 3090 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:59.434811 [ 17626 ] {9a9496cf-d46d-48f5-b09f-c2958cb78b7a} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43146) (comment: 01666_gcd_ubsan.sql) (in query: SELECT lcm(-170141183460469231731687303715884105728, -170141183460469231731687303715884105728);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012e9f8f1 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012d3cb69 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:38:59.443617 [ 17626 ] {9a9496cf-d46d-48f5-b09f-c2958cb78b7a} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000ac6cd20 4. DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x0000000012e9f8f1 5. DB::BinaryArithmeticOverloadResolver::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x0000000012d3cb69 6. DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c2b7b32 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:38:59.518160 [ 3089 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:59.518278 [ 3094 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:59.555766 [ 3093 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:59.704779 [ 16881 ] {6c006977-3d7e-42fa-bf08-e229932caef3} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43194) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:59.719356 [ 16881 ] {6c006977-3d7e-42fa-bf08-e229932caef3} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:38:59.813306 [ 3058 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:38:59.832757 [ 3065 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.015817 [ 3088 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.167757 [ 3097 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.318613 [ 3096 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.507852 [ 16881 ] {b298ea44-d5fa-4e67-945b-eb802af1ae83} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43202) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:00.519140 [ 16881 ] {b298ea44-d5fa-4e67-945b-eb802af1ae83} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:00.520918 [ 3066 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.521306 [ 3059 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.558269 [ 3136 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.871935 [ 3174 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:00.872555 [ 3161 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.018579 [ 3182 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.170179 [ 3143 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.234429 [ 16551 ] {1e6d5814-17e6-484d-9bdf-65ed5da730a9} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43218) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:01.262812 [ 16551 ] {1e6d5814-17e6-484d-9bdf-65ed5da730a9} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:01.321152 [ 3173 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.523643 [ 3194 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.524086 [ 3175 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.560794 [ 3178 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.874563 [ 3205 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.874960 [ 3200 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:01.953867 [ 16551 ] {f0c28913-d1b0-4d38-9b92-d113c5ad55e7} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43222) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:01.966419 [ 16551 ] {f0c28913-d1b0-4d38-9b92-d113c5ad55e7} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:02.021709 [ 3197 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:02.173441 [ 3130 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:02.323709 [ 3241 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:02.526250 [ 3230 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:02.526522 [ 3249 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:02.563097 [ 3250 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:02.679043 [ 16551 ] {bbd3ea80-ab4e-4395-bae7-8e26b7dfb9a3} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43234) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:02.683714 [ 16551 ] {bbd3ea80-ab4e-4395-bae7-8e26b7dfb9a3} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:02.877695 [ 3252 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:02.878567 [ 3260 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.025348 [ 3229 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.175853 [ 3281 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.331112 [ 3209 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.509449 [ 16551 ] {9c4117af-e1a5-4728-8f25-88f570bbb27f} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43238) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:03.533468 [ 3232 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.533745 [ 3245 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.550432 [ 16551 ] {9c4117af-e1a5-4728-8f25-88f570bbb27f} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:03.565198 [ 3273 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.568405 [ 16881 ] {c3b579f3-858b-453d-a7ef-01cfcb6d1591} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43208) (comment: 01890_state_of_state.sql) (in query: SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000245704f9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 9. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x00000000121d4123 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:39:03.579259 [ 16881 ] {c3b579f3-858b-453d-a7ef-01cfcb6d1591} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000245704f9 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 9. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x00000000121d4123 10. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 11. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 12. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 13. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 23. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 26. ./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&) @ 0x000000002942671d 27. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 29. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 31. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 2025.10.15 20:39:03.880626 [ 3301 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:03.880800 [ 3269 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.084256 [ 3228 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.178896 [ 3262 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.271296 [ 16551 ] {87f06067-3664-41d4-87a7-b480b10a1ef7} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43248) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:04.275643 [ 16551 ] {87f06067-3664-41d4-87a7-b480b10a1ef7} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:04.334039 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.536074 [ 3280 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.539201 [ 3297 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.567519 [ 3275 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.696895 [ 16881 ] {f7921f29-d350-4656-961d-46f8072ebf55} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43208) (comment: 01890_state_of_state.sql) (in query: SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d99699 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d596e9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 10. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x00000000121d4123 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 30. ./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&) @ 0x000000002942671d 31. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 2025.10.15 20:39:04.704417 [ 16881 ] {f7921f29-d350-4656-961d-46f8072ebf55} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: _ZN2DBL34createAggregateFunctionSingleValueITtTyTpTnbENS_12_GLOBAL__N_123AggregateFunctionMinMaxELb1EJLb0EEEEPNS_18IAggregateFunctionERKNSt3__112basic_stringIcNS5_11char_traitsIcEENS5_9allocatorIcEEEERKNS5_6vectorINS5_10shared_ptrIKNS_9IDataTypeEEENS9_ISI_EEEERKNS_5ArrayEPKNS_8SettingsE @ 0x0000000023d99699 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000023d596e9 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 10. DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x00000000121d4123 11. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd576e 12. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd5176 13. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd6343 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839da90 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 27. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 28. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 30. ./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&) @ 0x000000002942671d 31. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 2025.10.15 20:39:04.883123 [ 3293 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.883742 [ 3283 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:04.986666 [ 16551 ] {b94ea312-9bc9-4ce0-895c-a496f2f2213e} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43260) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:04.996951 [ 16551 ] {b94ea312-9bc9-4ce0-895c-a496f2f2213e} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:05.089824 [ 3263 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:05.181440 [ 3303 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:05.269684 [ 16881 ] {50c0a0ff-7001-4213-abb4-9fe7d0e7fafe} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43208) (comment: 01890_state_of_state.sql) (in query: SELECT toTypeName(quantileState(x)) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000022cd1765 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839dd27 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:39:05.283866 [ 16881 ] {50c0a0ff-7001-4213-abb4-9fe7d0e7fafe} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000022cd1765 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839dd27 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 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&) @ 0x0000000029423ad3 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&) @ 0x000000002941e2af 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&) @ 0x000000002942671d 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 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*) @ 0x0000000029b3b99b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 2025.10.15 20:39:05.337889 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:05.538938 [ 2828 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:05.541689 [ 3292 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:05.570375 [ 2823 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:05.572704 [ 16881 ] {44f2093e-e725-4fd4-9b57-1810a8a0579b} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:43208) (comment: 01890_state_of_state.sql) (in query: SELECT hex(toString(quantileState(x))) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000022cd1765 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839dd27 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:39:05.584843 [ 16881 ] {44f2093e-e725-4fd4-9b57-1810a8a0579b} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000c310a7a 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000022cd1765 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000265b779e 6. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 7. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b74da 8. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b4a12 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839dd27 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839586e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002836b54e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028369c10 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9d69 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002835e783 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000002835ca84 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x000000002835b88d 22. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922268c 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000029423ad3 24. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002941e2af 25. ./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&) @ 0x000000002942671d 26. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002934b4db 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3b99b 28. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 29. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 30. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 31. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 2025.10.15 20:39:05.739507 [ 16551 ] {0f49133b-f2f2-46d8-90c5-ff791621eee2} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49554) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:05.750421 [ 16551 ] {0f49133b-f2f2-46d8-90c5-ff791621eee2} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:05.886003 [ 3191 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:05.886953 [ 3331 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.092329 [ 2838 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.184250 [ 3328 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.340454 [ 2846 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.508546 [ 17626 ] {29bb1ef7-efb8-4667-b79c-c82101b95a86} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49566) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:06.534550 [ 17626 ] {29bb1ef7-efb8-4667-b79c-c82101b95a86} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:06.541665 [ 2851 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.543826 [ 3332 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.573399 [ 2872 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.888488 [ 2842 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:06.889681 [ 2881 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.094832 [ 2863 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.187083 [ 2853 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.266535 [ 12800 ] {8e57d9ac-694b-4f00-8031-105bca96ccc0} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49598) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:07.295777 [ 12800 ] {8e57d9ac-694b-4f00-8031-105bca96ccc0} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:07.343263 [ 2880 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.546028 [ 3335 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.546806 [ 2855 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.577154 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.890932 [ 2928 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.892127 [ 2923 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:07.967933 [ 12800 ] {34b4ab5e-9dc2-42ae-8725-3e8865e33942} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49614) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:07.983748 [ 12800 ] {34b4ab5e-9dc2-42ae-8725-3e8865e33942} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:08.097233 [ 2900 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:08.189514 [ 2904 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:08.346127 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:08.611871 [ 2878 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:08.612190 [ 2891 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:08.613119 [ 2870 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:08.817118 [ 17626 ] {ad392e90-f940-446b-bb87-8aaee9a574ff} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49628) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:08.833370 [ 17626 ] {ad392e90-f940-446b-bb87-8aaee9a574ff} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:08.894120 [ 2930 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:08.894841 [ 2915 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.100215 [ 2916 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.192950 [ 2946 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.349191 [ 2829 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.576288 [ 17626 ] {680deb85-04ab-4e5a-84ec-e9126acb099b} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49638) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:09.587537 [ 17626 ] {680deb85-04ab-4e5a-84ec-e9126acb099b} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:09.615004 [ 2892 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.615708 [ 2937 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.616209 [ 2951 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.897299 [ 2967 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:09.896717 [ 2973 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.110394 [ 2969 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.195072 [ 2964 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.358875 [ 2956 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.539445 [ 17626 ] {092c8e09-c42c-493d-818b-c4892e42b3a6} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49658) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:10.562925 [ 17626 ] {092c8e09-c42c-493d-818b-c4892e42b3a6} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:10.618109 [ 2927 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.621053 [ 2944 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.621399 [ 2950 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.900383 [ 2996 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:10.907145 [ 3004 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.121729 [ 2984 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.198677 [ 3008 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.288762 [ 17626 ] {74bd471d-4478-466d-8a12-9446cd7f51ea} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49670) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:11.294436 [ 17626 ] {74bd471d-4478-466d-8a12-9446cd7f51ea} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:11.364917 [ 2980 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.620871 [ 3021 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.624021 [ 3038 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.624767 [ 3037 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.902462 [ 3048 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:11.909610 [ 3016 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.009552 [ 17626 ] {fd4aeaaa-72cd-4d28-b485-80c80a0247a9} executeQuery: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_QUERY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:49688) (comment: 02555_davengers_rename_chain.sh) (in query: SHOW CREATE TABLE wrong_metadata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:12.026471 [ 17626 ] {fd4aeaaa-72cd-4d28-b485-80c80a0247a9} TCPHandler: Code: 390. DB::Exception: Table `wrong_metadata` doesn't exist. (CANNOT_GET_CREATE_TABLE_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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Databases/DatabaseOnDisk.cpp:524: DB::DatabaseOnDisk::getCreateTableQueryImpl(String const&, std::shared_ptr, bool) const @ 0x0000000027cd96b8 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterShowCreateQuery::executeImpl() @ 0x0000000029be99ef 6. ./build_docker/./src/Interpreters/InterpreterShowCreateQuery.cpp:0: DB::InterpreterShowCreateQuery::execute() @ 0x0000000029be907f 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:12.123810 [ 3090 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.200734 [ 3099 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.419636 [ 3117 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.623313 [ 3105 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.627188 [ 3080 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.708211 [ 3058 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.904836 [ 3128 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:12.911613 [ 3088 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.126787 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.203219 [ 3126 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.423044 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.626515 [ 3138 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.630140 [ 3122 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.710929 [ 3162 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.907554 [ 3155 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:13.914146 [ 3183 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.129613 [ 3150 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.207462 [ 3131 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.433971 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.629827 [ 3222 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.632381 [ 3240 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.713515 [ 3216 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.910539 [ 3244 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:14.922754 [ 3230 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.132432 [ 3247 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.209539 [ 3252 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.338128 [ 17626 ] {3045be05-2365-4ec5-9922-d604c4f6209a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:52898) (comment: 02428_combinators_with_over_statement.sql) (in query: DROP DATABASE IF EXISTS test_tbo3a1t5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:39:15.345942 [ 17626 ] {3045be05-2365-4ec5-9922-d604c4f6209a} DynamicQueryHandler: Code: 219. DB::Exception: New table 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:591: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286b93e7 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>>>&) @ 0x00000000291fbef0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.436421 [ 3237 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.547449 [ 12800 ] {22f384e2-d5c4-44b1-af5c-ca9c4daa708e} 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.10521.altinitytest (altinity build)) (from [::1]:52910) (comment: 02428_combinators_with_over_statement.sql) (in query: DROP DATABASE IF EXISTS test_tbo3a1t5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:39:15.556000 [ 12800 ] {22f384e2-d5c4-44b1-af5c-ca9c4daa708e} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000291fb72a 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 13. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 14. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 15. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.632458 [ 3295 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.634463 [ 3276 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.715806 [ 3286 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.912579 [ 3279 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:15.924666 [ 3199 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.136421 [ 3284 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.211893 [ 3268 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.438830 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.635418 [ 3263 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.637197 [ 3315 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.718173 [ 3259 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.915102 [ 2840 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:16.927024 [ 3323 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.147379 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.216217 [ 2850 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.441695 [ 2837 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.639159 [ 2831 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.639662 [ 2871 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.720520 [ 2853 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.917271 [ 3335 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.918244 [ 3441 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a58126e5-943b-4092-9d19-33afc9a0cd35::202510_1_171_67}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:17.929845 [ 2873 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.149634 [ 2926 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.218838 [ 2904 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.444314 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.647813 [ 2924 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.649023 [ 2884 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.723688 [ 2870 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.920563 [ 2841 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:18.934408 [ 2930 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.152177 [ 2939 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.221134 [ 2952 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.449509 [ 2936 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.652036 [ 2967 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.652264 [ 2973 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.777462 [ 2962 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.923339 [ 2917 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:19.936733 [ 2971 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.154575 [ 2968 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.224493 [ 2982 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.458838 [ 3042 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.654592 [ 3093 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.654882 [ 3103 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.834903 [ 3095 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.998604 [ 3110 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:20.999233 [ 3167 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:21.157620 [ 3235 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:21.227383 [ 3209 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:21.462136 [ 3296 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:21.657079 [ 3319 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:21.657649 [ 3313 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:21.838433 [ 3323 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.044796 [ 2823 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.044858 [ 3287 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.159750 [ 3334 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.230135 [ 2850 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.466621 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.659491 [ 2872 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.667475 [ 2857 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:22.841560 [ 2854 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.046839 [ 2846 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.050579 [ 2848 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.165464 [ 2859 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.288101 [ 2853 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.469472 [ 2883 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.661893 [ 2901 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.672095 [ 2873 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:23.843464 [ 2861 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.049198 [ 2907 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.059577 [ 2912 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.167920 [ 2878 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.290661 [ 2930 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.472127 [ 2932 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.664534 [ 2911 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.683443 [ 2934 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:24.845895 [ 2973 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.051604 [ 2974 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.061694 [ 2994 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.170164 [ 2933 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.292926 [ 3159 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.474488 [ 2998 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.667296 [ 3021 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.686181 [ 3038 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:25.848634 [ 3047 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.053733 [ 3044 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.063959 [ 3048 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.267368 [ 3057 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.295469 [ 3064 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.476481 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.523212 [ 23276 ] {7b94890f-5d7c-4f27-8109-1b00c5d53980} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38358) (comment: 00964_bloom_index_string_functions.sh) (in query: SELECT * FROM bloom_filter_idx WHERE multiSearchAny(s, ['base', 'seme', 'gement']) FORMAT JSON), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:39:26.537703 [ 23276 ] {7b94890f-5d7c-4f27-8109-1b00c5d53980} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c8350fa 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0f771 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002deb39f9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d35925c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 2025.10.15 20:39:26.671461 [ 3107 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.691142 [ 3078 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:26.851472 [ 3049 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.073652 [ 3087 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.089777 [ 3073 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.270954 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.298018 [ 3080 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.483089 [ 3065 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.765155 [ 3111 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.765448 [ 3067 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:27.853964 [ 3079 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.077197 [ 3088 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.093043 [ 3140 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.274360 [ 3118 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.394546 [ 3125 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.486535 [ 3126 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.767370 [ 3101 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.767743 [ 3059 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:28.857240 [ 3095 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.080280 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.095932 [ 3137 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.277765 [ 3160 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.396818 [ 3154 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.495322 [ 3188 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.769842 [ 3180 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.770054 [ 3194 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:29.859683 [ 3192 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.082984 [ 3175 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.122553 [ 3224 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.280044 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.399118 [ 3190 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.498114 [ 3222 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.772953 [ 3241 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.774735 [ 3216 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:30.862229 [ 3230 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.084985 [ 3254 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.124757 [ 3211 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.282704 [ 3247 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.401114 [ 3242 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.502959 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.777153 [ 3229 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.778043 [ 3265 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:31.864866 [ 3256 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.087636 [ 3195 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.126846 [ 3291 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.285156 [ 3295 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.403897 [ 3213 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.506992 [ 3257 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.635807 [ 17626 ] {3b161d99-0dc1-474b-948e-8859b0492dc1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38426) (comment: 00964_bloom_index_string_functions.sh) (in query: SELECT * FROM bloom_filter_idx WHERE multiSearchAny(s, ['adab', 'cad', 'aba']) AND (startsWith(s, 'c') OR startsWith(s, '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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x000000002c6a1915 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1355: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x000000002c662432 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:678: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool)::$_0::operator()(unsigned long) const @ 0x000000002c65e8fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000002c6599d8 13. ./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) @ 0x000000002de484fd 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 16. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:39:32.656351 [ 17626 ] {3b161d99-0dc1-474b-948e-8859b0492dc1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::MergeTreeIndexReader::MergeTreeIndexReader(std::shared_ptr, std::shared_ptr, unsigned long, DB::MarkRanges const&, DB::MarkCache*, DB::UncompressedCache*, DB::MergeTreeReaderSettings) @ 0x000000002c6a1915 10. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:1355: DB::MergeTreeDataSelectExecutor::filterMarksUsingIndex(std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MarkRanges const&, DB::Settings const&, DB::MergeTreeReaderSettings const&, DB::MarkCache*, DB::UncompressedCache*, std::shared_ptr) @ 0x000000002c662432 11. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:678: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool)::$_0::operator()(unsigned long) const @ 0x000000002c65e8fd 12. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:0: DB::MergeTreeDataSelectExecutor::filterPartsByPrimaryKeyAndSkipIndexes(std::vector, std::allocator>>&&, std::shared_ptr, std::shared_ptr const&, DB::KeyCondition const&, std::optional const&, DB::UsefulSkipIndexes const&, DB::MergeTreeReaderSettings const&, std::shared_ptr, unsigned long, std::vector>&, bool, bool) @ 0x000000002c6599d8 13. ./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) @ 0x000000002de484fd 14. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de4604f 15. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de51cc5 16. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de549cc 17. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddc9ffc 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de0fdde 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942593f 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x00000000294251a7 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 29. asan_thread_start(void*) @ 0x000000000aa45059 30. ? @ 0x00007f2f94fabac3 31. ? @ 0x00007f2f9503d850 2025.10.15 20:39:32.780244 [ 3278 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.781186 [ 3301 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:32.868295 [ 3273 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.090102 [ 3239 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.129217 [ 3248 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.287873 [ 3279 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.406093 [ 2954 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.512048 [ 3264 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.783186 [ 2959 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.784326 [ 2955 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:33.888543 [ 2983 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.092176 [ 3016 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.131422 [ 3169 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.290636 [ 3275 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.408534 [ 3274 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.515363 [ 2966 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.787289 [ 3302 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.793176 [ 3304 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:34.891703 [ 3259 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.100282 [ 3316 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.133802 [ 2839 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.293075 [ 3191 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.410822 [ 3324 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.521532 [ 3309 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.790177 [ 2835 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.802656 [ 2837 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:35.846462 [ 23276 ] {6c4f58a9-ed54-41eb-a883-676ed9014f06} executeQuery: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:38424) (comment: 02597_column_update_and_replication.sql) (in query: ALTER TABLE test DROP COLUMN x 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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 @ 0x000000002c538c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000002c4a76a7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49d8da 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:35.859099 [ 23276 ] {6c4f58a9-ed54-41eb-a883-676ed9014f06} TCPHandler: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 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 @ 0x000000002c538c5a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000002c4a76a7 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49d8da 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:35.893914 [ 2830 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.104077 [ 2859 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.136462 [ 2877 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.295397 [ 2865 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.413286 [ 2895 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.528395 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.776933 [ 3448 ] {} eda66b7a-b33c-44bf-9f24-570f394967e0::all_0_0_0_4 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.779613 [ 3448 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {eda66b7a-b33c-44bf-9f24-570f394967e0::all_0_0_0_4}: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.793167 [ 2910 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.805568 [ 2905 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:36.895972 [ 2904 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.106045 [ 2878 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.139823 [ 2870 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.303465 [ 2930 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.419191 [ 2914 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.531520 [ 2939 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.797702 [ 2829 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.809385 [ 2940 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:37.912268 [ 2918 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.108646 [ 2892 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.143144 [ 2936 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.302169 [ 17626 ] {096a89d6-93fe-4216-bdc8-e68bb0023d01} executeQuery: Code: 36. DB::Exception: Existing column a is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37938) (comment: 00754_alter_modify_order_by.sql) (in query: ALTER TABLE no_order MODIFY ORDER BY (a);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:650: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d026 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:38.310154 [ 2994 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.317987 [ 17626 ] {096a89d6-93fe-4216-bdc8-e68bb0023d01} TCPHandler: Code: 36. DB::Exception: Existing column a is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:650: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d026 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:38.422050 [ 2917 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.538526 [ 2996 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.849866 [ 3159 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.850045 [ 2997 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:38.914738 [ 2995 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.048692 [ 17626 ] {9e2182be-44ef-4e21-97b0-fc57e62b5fad} executeQuery: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37938) (comment: 00754_alter_modify_order_by.sql) (in query: ALTER TABLE old_style ADD COLUMN y UInt32, MODIFY ORDER BY (x, y);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3380: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a1b0b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:39.056347 [ 17626 ] {9e2182be-44ef-4e21-97b0-fc57e62b5fad} TCPHandler: Code: 36. DB::Exception: ALTER MODIFY ORDER BY is not supported for default-partitioned tables created with the old syntax. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3380: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a1b0b 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:39.112713 [ 3010 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.145589 [ 2975 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.312463 [ 2990 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.424738 [ 3013 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.541787 [ 2992 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.597494 [ 17626 ] {54edf064-fb9f-440d-806c-cb1ee10a1fb1} executeQuery: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37938) (comment: 00754_alter_modify_order_by.sql) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing MODIFY ORDER BY (x, y, -val);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:650: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d026 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:39.601630 [ 17626 ] {54edf064-fb9f-440d-806c-cb1ee10a1fb1} TCPHandler: Code: 36. DB::Exception: Existing column val is used in the expression that was added to the sorting key. You can add expressions that use only the newly added columns. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:650: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d026 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:39.856959 [ 3015 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.857866 [ 3019 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:39.917428 [ 3022 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.115569 [ 3060 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.148440 [ 3006 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.386900 [ 3103 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.427342 [ 3120 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.544818 [ 3174 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.870469 [ 3252 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.873677 [ 3207 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:40.923140 [ 3246 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.127029 [ 3297 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.151666 [ 3323 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.380635 [ 17626 ] {7f786464-1a80-43c0-9103-98759579ba66} executeQuery: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37938) (comment: 00754_alter_modify_order_by.sql) (in query: /* Can't add an expression with existing column to ORDER BY. */ ALTER TABLE summing ADD COLUMN z UInt32 DEFAULT x + 1, MODIFY ORDER BY (x, y, -z);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:656: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d33e 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:41.384190 [ 17626 ] {7f786464-1a80-43c0-9103-98759579ba66} TCPHandler: Code: 36. DB::Exception: Newly added column z has a default expression, so adding expressions that use it to the sorting key is forbidden. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad6b34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:656: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d33e 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:41.390757 [ 2862 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.430103 [ 2867 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.527395 [ 17626 ] {76a7d451-da9a-41d0-a269-9f0e5b1bb9b9} executeQuery: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent' 'x' 'y' 'nonexistent'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37938) (comment: 00754_alter_modify_order_by.sql) (in query: /* Can't add nonexistent column to ORDER BY. */ ALTER TABLE summing MODIFY ORDER BY (x, y, nonexistent);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299a44bc 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 @ 0x00000000299b752a 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000002b6a4cf1 6. ./build_docker/./src/Storages/KeyDescription.cpp:75: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000002b6a4168 7. ./build_docker/./src/Storages/AlterCommands.cpp:610: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5f7020 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b603f9c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49c610 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:39:41.545017 [ 17626 ] {76a7d451-da9a-41d0-a269-9f0e5b1bb9b9} TCPHandler: Code: 47. DB::Exception: Missing columns: 'nonexistent' while processing query: 'x, y, nonexistent', required columns: 'x' 'y' 'nonexistent' 'x' 'y' 'nonexistent'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299a44bc 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 @ 0x00000000299b752a 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000002b6a4cf1 6. ./build_docker/./src/Storages/KeyDescription.cpp:75: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000002b6a4168 7. ./build_docker/./src/Storages/AlterCommands.cpp:610: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b5f7020 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b603f9c 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49c610 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 11. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 20. asan_thread_start(void*) @ 0x000000000aa45059 21. ? @ 0x00007f2f94fabac3 22. ? @ 0x00007f2f9503d850 2025.10.15 20:39:41.547592 [ 2865 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.733695 [ 17626 ] {7a6d8536-e553-46ee-a931-d8024a733e5b} executeQuery: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37938) (comment: 00754_alter_modify_order_by.sql) (in query: /* Can't modyfy ORDER BY so that it is no longer a prefix of the PRIMARY KEY. */ ALTER TABLE summing MODIFY 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7b4ba 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:589: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:41.739681 [ 17626 ] {7a6d8536-e553-46ee-a931-d8024a733e5b} TCPHandler: Code: 36. DB::Exception: Primary key must be a prefix of the sorting key, but its length: 2 is greater than the sorting key length: 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7b4ba 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:589: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, std::shared_ptr) const @ 0x000000002c44d4cf 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3542: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c49f8fc 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 16. asan_thread_start(void*) @ 0x000000000aa45059 17. ? @ 0x00007f2f94fabac3 18. ? @ 0x00007f2f9503d850 2025.10.15 20:39:41.873416 [ 2869 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.876398 [ 2902 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:41.926595 [ 2885 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.129670 [ 2900 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.154142 [ 2910 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.394086 [ 2904 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.432144 [ 2943 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.553834 [ 2912 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.808224 [ 12800 ] {e90c30f5-f850-41a2-958c-ee71fe9f7a6f} executeQuery: Code: 57. DB::Exception: Table test_1.t2 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37964) (comment: 02815_join_algorithm_setting.sql) (in query: CREATE TABLE t2 ( `k` UInt16 ) 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:42.819418 [ 12800 ] {e90c30f5-f850-41a2-958c-ee71fe9f7a6f} TCPHandler: Code: 57. DB::Exception: Table test_1.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c13bf 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b19dc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c81d5 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:42.937274 [ 2841 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.938086 [ 2930 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:42.938946 [ 2935 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.141021 [ 2940 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.244879 [ 2916 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.396948 [ 2942 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.443489 [ 2948 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.556434 [ 2922 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.939797 [ 2973 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.940904 [ 2969 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:43.941406 [ 2974 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.143938 [ 2961 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.248062 [ 2944 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.399988 [ 2988 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.445860 [ 2960 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.560684 [ 3159 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.819632 [ 17626 ] {a8a08c88-194d-48f7-adad-505a825efd53} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37970) (comment: 01851_clear_column_referenced_by_mv.sql) (in query: ALTER TABLE `01851_merge_tree` DROP COLUMN n3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a2dd3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:44.824166 [ 17626 ] {a8a08c88-194d-48f7-adad-505a825efd53} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a2dd3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:44.942643 [ 2949 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.943965 [ 2998 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.944306 [ 3011 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:44.982239 [ 17626 ] {2de5ba58-b48d-47ec-9ac4-6ab2326a5e94} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37970) (comment: 01851_clear_column_referenced_by_mv.sql) (in query: ALTER TABLE `01851_merge_tree` DROP COLUMN n2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a2dd3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:44.987454 [ 17626 ] {2de5ba58-b48d-47ec-9ac4-6ab2326a5e94} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01851_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa93e9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3446: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a2dd3 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029178152 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x0000000029174331 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b35fe5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d186c4c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:45.156039 [ 3009 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:45.251060 [ 3003 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:45.403513 [ 3007 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:45.448684 [ 3015 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:45.563403 [ 3060 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:45.945171 [ 3025 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:45.946557 [ 3042 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:45.947321 [ 3036 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.158599 [ 3040 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.253964 [ 3057 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.406463 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.451760 [ 3052 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.568493 [ 3068 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.797653 [ 16871 ] {7c77488d-0e76-4df3-a05d-5ecf5f412da2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=769, jobs=760). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:37966) (comment: 01036_no_superfluous_dict_reload_on_create_database.sql) (in query: SELECT query_count FROM system.dictionaries WHERE database = currentDatabase() AND name = 'dict';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:46.802309 [ 16871 ] {7c77488d-0e76-4df3-a05d-5ecf5f412da2} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=769, jobs=760). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af89357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7d331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af7e453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d379ced 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d37a93f 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d19ba5b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d186f2a 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1baa80 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 15. asan_thread_start(void*) @ 0x000000000aa45059 16. ? @ 0x00007f2f94fabac3 17. ? @ 0x00007f2f9503d850 2025.10.15 20:39:46.951012 [ 3049 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.951426 [ 3077 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:46.952445 [ 3087 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.161092 [ 3111 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.204189 [ 16881 ] {9655fdd9-0dcd-4f34-8914-941e406dac4e} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:33242) (comment: 01036_no_superfluous_dict_reload_on_create_database.sql) (in query: DROP DATABASE IF EXISTS test_kbuqw88x ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 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>>>&) @ 0x00000000291fb9cc 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 2025.10.15 20:39:47.207026 [ 16881 ] {9655fdd9-0dcd-4f34-8914-941e406dac4e} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aaca68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291f839c 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>>>&) @ 0x00000000291fb9cc 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291f4557 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291f27d1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291f20ad 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 18. asan_thread_start(void*) @ 0x000000000aa45059 19. ? @ 0x00007f2f94fabac3 20. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.256985 [ 3098 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.408835 [ 3140 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.453972 [ 3070 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.663742 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.954202 [ 3089 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.954900 [ 3063 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:47.954988 [ 3058 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.163849 [ 3100 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.259467 [ 3129 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.411307 [ 3113 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.456423 [ 3119 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.666616 [ 3115 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.957062 [ 3145 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.962165 [ 3137 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:48.962407 [ 3152 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.128271 [ 3163 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.166661 [ 3160 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.262303 [ 3153 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.448874 [ 3076 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.459325 [ 3161 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.669331 [ 3178 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.960207 [ 3176 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.965044 [ 3192 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:49.965599 [ 3204 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.169094 [ 3172 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.264985 [ 3198 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.451268 [ 3221 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.461713 [ 3241 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.680314 [ 3230 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.993279 [ 3211 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.993607 [ 3252 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:50.995070 [ 3207 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.171533 [ 3236 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.270361 [ 3223 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.453971 [ 3291 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.464122 [ 3246 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.683067 [ 3202 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.996564 [ 3239 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.997081 [ 3248 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:51.998086 [ 3300 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:52.174298 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:52.280776 [ 3321 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:52.457802 [ 3328 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:52.472489 [ 3309 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:52.714075 [ 2883 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:52.999275 [ 3020 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:53.000268 [ 3064 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:53.005731 [ 3041 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:53.194911 [ 3089 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:53.285447 [ 3170 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:53.464548 [ 3131 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:53.474949 [ 3168 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:53.717759 [ 3192 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.006535 [ 3224 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.007814 [ 3212 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.008882 [ 3172 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.198377 [ 3193 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.288567 [ 3171 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.467036 [ 3222 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.477460 [ 3240 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:54.722801 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.012271 [ 3252 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.012402 [ 3207 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.013635 [ 3247 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.200984 [ 3177 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.298037 [ 3236 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.470399 [ 3208 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.480195 [ 3237 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:55.730585 [ 3246 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.014764 [ 3213 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.015873 [ 3278 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.015931 [ 3257 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.203534 [ 3245 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.304683 [ 2981 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.414972 [ 17626 ] {3938ae00-c2c9-4034-a2e7-2fd40b13bcb5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:47022) (comment: 02730_with_fill_by_sorting_prefix.sql) (in query: select * from ts order by sensor_id, timestamp with fill from 6 step 1 interpolate (value as 9999) settings use_with_fill_by_sorting_prefix=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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:39:56.421874 [ 17626 ] {3938ae00-c2c9-4034-a2e7-2fd40b13bcb5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c80cd91 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&) @ 0x000000002c80ebf5 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa1dd5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa23e5 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c808975 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) @ 0x000000002c80804a 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&) @ 0x000000002c5f5a66 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 @ 0x000000002c5ed5ee 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83498b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deac314 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df01ccc 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c82e5f2 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de7d6da 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d339b81 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d373ace 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35a8b1 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 30. asan_thread_start(void*) @ 0x000000000aa45059 31. ? @ 0x00007f2f94fabac3 2025.10.15 20:39:56.473353 [ 3294 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.483613 [ 3016 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:56.733793 [ 3280 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.017733 [ 3134 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.019521 [ 2956 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.019695 [ 3255 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.207201 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.308730 [ 2827 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.476354 [ 2902 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.486611 [ 2887 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:57.736359 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.020702 [ 2897 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.022748 [ 2913 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.023358 [ 2875 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.210134 [ 2947 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.311751 [ 2874 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.479570 [ 2930 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.489680 [ 2935 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:58.742510 [ 2866 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.024755 [ 2942 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.025372 [ 2941 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.026234 [ 2948 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.213399 [ 2921 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.314478 [ 2937 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.483484 [ 2994 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.492967 [ 2965 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:39:59.745773 [ 2971 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.027254 [ 2996 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.028281 [ 2993 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.028605 [ 2988 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.216111 [ 2933 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.317541 [ 2972 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.487137 [ 3002 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.496234 [ 3004 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:00.749396 [ 2975 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.029784 [ 3006 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.032488 [ 3042 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.034343 [ 3025 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.219028 [ 3057 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.320142 [ 3020 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.490264 [ 3064 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.498837 [ 2999 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:01.752547 [ 3013 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.033344 [ 3017 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.036352 [ 2990 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.037351 [ 3048 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.221415 [ 3090 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.323082 [ 3078 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.492889 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.501815 [ 3105 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:02.755786 [ 3055 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.036897 [ 3102 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.040301 [ 3061 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.042177 [ 3081 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.224067 [ 3099 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.326519 [ 3063 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.495918 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.504644 [ 3094 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:03.759534 [ 3126 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.040998 [ 3108 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.043485 [ 3129 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.045995 [ 3097 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.226440 [ 3113 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.330641 [ 3096 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.498622 [ 3095 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.507146 [ 3084 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:04.762393 [ 3162 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.045718 [ 3170 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.046744 [ 3123 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.053926 [ 3086 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.234250 [ 3185 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.332738 [ 3158 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.500768 [ 3219 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.509683 [ 3181 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:05.766122 [ 3253 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.048735 [ 3111 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.050065 [ 3232 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.056198 [ 3289 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.236902 [ 3264 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.335108 [ 2955 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.503474 [ 3301 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.512399 [ 3149 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:06.769150 [ 3184 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.051973 [ 3175 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.052560 [ 3206 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.139839 [ 3224 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.239751 [ 3198 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.337789 [ 3130 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.506554 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.516310 [ 3197 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:07.772316 [ 3226 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.054893 [ 3234 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.055545 [ 3225 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.143128 [ 3252 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.324391 [ 3189 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.340623 [ 3242 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.510009 [ 3215 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.519663 [ 3260 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:08.775636 [ 3258 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.057579 [ 3229 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.057817 [ 3265 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.146093 [ 3220 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.327275 [ 3195 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.343841 [ 3291 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.548771 [ 3213 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.551331 [ 3278 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:09.778810 [ 3239 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.159983 [ 3245 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.160435 [ 2981 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.163828 [ 3280 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.330472 [ 3290 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.346737 [ 2966 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.552293 [ 3293 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.554579 [ 3329 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:10.781617 [ 3302 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.164536 [ 3316 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.166536 [ 2839 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.172926 [ 3323 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.185701 [ 3263 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.332754 [ 3303 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.348854 [ 2847 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.555626 [ 2845 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.557548 [ 3310 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:11.784129 [ 2828 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.167524 [ 3328 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.169764 [ 3309 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.175811 [ 3318 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.335603 [ 2824 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.352000 [ 2856 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.568531 [ 2857 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.568931 [ 2835 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:12.787423 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.181918 [ 3032 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.182003 [ 3000 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.182134 [ 3027 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.340834 [ 3037 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.355378 [ 3075 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.571293 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.572867 [ 2831 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:13.790661 [ 2864 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.186179 [ 3014 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.186363 [ 2909 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.186868 [ 2894 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.343357 [ 2890 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.357647 [ 2900 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.575413 [ 2923 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.575568 [ 2928 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:14.793822 [ 3199 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.189933 [ 2945 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.190871 [ 3262 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.245184 [ 3169 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.346448 [ 2927 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.360976 [ 3001 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.578841 [ 3305 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.579665 [ 3166 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:15.797413 [ 2904 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.199448 [ 2912 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.200038 [ 2844 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.248642 [ 3157 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.349974 [ 2906 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.364633 [ 2884 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.581985 [ 2907 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.582987 [ 2878 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:16.801272 [ 2898 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.202463 [ 2915 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.203617 [ 2903 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.251486 [ 2891 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.405033 [ 2893 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.405667 [ 2866 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.584755 [ 2916 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.586003 [ 2829 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:17.804999 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.205273 [ 2977 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.206261 [ 2946 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.254847 [ 2911 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.408837 [ 2973 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.409597 [ 2969 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.587909 [ 2917 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.589091 [ 2938 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:18.808879 [ 2962 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.209225 [ 2995 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.209842 [ 2963 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.259016 [ 3004 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.412600 [ 3028 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.413366 [ 3008 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.592379 [ 3010 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.592807 [ 2949 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:19.812175 [ 3009 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.212844 [ 3057 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.213445 [ 3040 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.262399 [ 3071 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.424593 [ 3020 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.425237 [ 3062 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.595718 [ 3064 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.596642 [ 2999 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:20.815715 [ 3045 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.216355 [ 3019 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.217258 [ 3017 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.267219 [ 3024 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.427159 [ 3069 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.428110 [ 3005 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.598265 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.600318 [ 3078 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:21.819045 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.219533 [ 3140 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.220597 [ 3055 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.267163 [ 3061 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.275996 [ 3116 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.429668 [ 3094 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.430729 [ 3156 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.605485 [ 3108 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.605815 [ 3129 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:22.821948 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.222247 [ 3118 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.223589 [ 3144 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.278524 [ 3113 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.433084 [ 3096 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.433745 [ 3127 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.608518 [ 3147 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.609047 [ 3095 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:23.825560 [ 3145 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.225504 [ 3153 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.226784 [ 3174 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.281541 [ 3155 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.436633 [ 3188 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.437297 [ 3142 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.612723 [ 3076 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.613361 [ 3146 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:24.829559 [ 3181 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.229074 [ 2914 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.230136 [ 3111 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.284798 [ 3232 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.439920 [ 3259 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.440719 [ 3082 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.616277 [ 2958 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.618196 [ 3307 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:25.833013 [ 2955 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.231992 [ 3176 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.233184 [ 3184 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.288168 [ 3192 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.455020 [ 3187 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.456936 [ 3206 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.619048 [ 3193 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.718150 [ 3224 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:26.836185 [ 3110 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.234901 [ 3252 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.236225 [ 3247 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.291233 [ 3189 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.467560 [ 3260 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.468693 [ 3215 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.623558 [ 3240 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.720998 [ 3216 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:27.844394 [ 3244 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.237568 [ 3238 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.241263 [ 3229 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.293523 [ 3208 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.471971 [ 3291 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.472548 [ 3246 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.626421 [ 3213 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.729135 [ 3257 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:28.847146 [ 3271 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.208141 [ 3321 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.243457 [ 3243 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.244846 [ 3255 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.296803 [ 3299 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.484890 [ 3182 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.485105 [ 3320 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.631656 [ 3268 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.733490 [ 3293 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:29.850246 [ 3297 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.246116 [ 3298 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.247364 [ 3282 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.299542 [ 3316 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.487946 [ 3314 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.488388 [ 3263 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.634599 [ 3315 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.736229 [ 3287 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:30.852932 [ 2845 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.249868 [ 3324 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.250848 [ 2825 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.302252 [ 3326 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.490930 [ 2833 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.491622 [ 2851 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.637239 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.801024 [ 2872 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:31.938385 [ 2835 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.253061 [ 2842 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.254295 [ 2871 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.305893 [ 3029 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.494711 [ 3034 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.495750 [ 3000 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.640160 [ 2991 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.803975 [ 3035 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:32.951531 [ 2881 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.255593 [ 2862 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.256650 [ 2867 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.311766 [ 2865 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.497842 [ 3014 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.499155 [ 2909 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.643338 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.807294 [ 2902 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:33.954987 [ 2885 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.261867 [ 2836 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.262642 [ 3276 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.314421 [ 2927 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.501240 [ 3305 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.502701 [ 3166 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.648075 [ 2861 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.810943 [ 2912 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:34.957954 [ 3275 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.264977 [ 3122 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.265520 [ 3286 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.317525 [ 2875 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.504725 [ 3288 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.506317 [ 3270 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.651780 [ 2920 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.814565 [ 2947 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:35.960500 [ 2841 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.268321 [ 2931 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.269294 [ 2932 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.321469 [ 2939 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.509013 [ 2916 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.513096 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.655206 [ 2942 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.822979 [ 2941 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:36.963937 [ 2934 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.271941 [ 2951 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.272713 [ 2937 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.325168 [ 2969 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.512180 [ 2994 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.516074 [ 2965 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.658758 [ 2961 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.826632 [ 2962 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:37.967193 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.276539 [ 3159 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.277245 [ 2968 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.328286 [ 2995 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.520165 [ 2987 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.520940 [ 3028 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.662328 [ 3009 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.830177 [ 3020 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:38.972565 [ 2972 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.279714 [ 3002 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.280414 [ 2997 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.331410 [ 3036 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.527152 [ 3031 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.528127 [ 2980 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.665488 [ 2992 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.833111 [ 3044 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:39.985125 [ 3085 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.282709 [ 3052 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.283307 [ 3039 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.334876 [ 3054 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.530836 [ 3053 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.530887 [ 3078 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.667793 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.836160 [ 3079 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:40.989028 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.286489 [ 3063 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.287451 [ 3125 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.338357 [ 3156 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.537365 [ 3103 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.538163 [ 3100 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.671205 [ 3114 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.839656 [ 3070 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:41.992307 [ 3074 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.289993 [ 3117 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.290827 [ 3144 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.341553 [ 3124 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.540674 [ 3059 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.541344 [ 3120 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.674759 [ 3115 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.844199 [ 3084 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:42.995627 [ 3162 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.293474 [ 3163 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.294386 [ 3123 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.344011 [ 3160 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.543889 [ 3153 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.545656 [ 3174 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.680491 [ 3066 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.850700 [ 3219 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:43.998852 [ 2959 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:44.296762 [ 3232 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:44.297727 [ 3289 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:44.346791 [ 3259 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:44.546976 [ 2896 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:44.550279 [ 3264 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:44.686297 [ 3173 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:44.854143 [ 3201 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.005896 [ 3192 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.300202 [ 3212 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.301236 [ 3172 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.409903 [ 3193 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.550017 [ 3110 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.553490 [ 3110 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.697550 [ 3130 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:45.857663 [ 3197 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.009105 [ 3252 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.302801 [ 3260 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.304509 [ 3215 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.413344 [ 3200 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.553429 [ 3205 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.556322 [ 3205 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.700587 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:46.861933 [ 3236 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.012288 [ 3254 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.305406 [ 3265 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.307965 [ 3223 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.416636 [ 3220 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.556616 [ 3208 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.558855 [ 3237 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.704387 [ 3291 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:47.867656 [ 3269 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.015434 [ 3295 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.308567 [ 3245 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.311213 [ 2981 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.419396 [ 3285 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.559924 [ 3134 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.569189 [ 2956 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.707275 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:48.870434 [ 3248 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.018921 [ 3317 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.311542 [ 3308 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.314132 [ 3319 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.423190 [ 3316 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.565370 [ 2839 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.572280 [ 3263 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.711594 [ 3292 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:49.872704 [ 3315 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.031719 [ 3331 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.313984 [ 2845 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.316455 [ 3191 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.431259 [ 2838 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.568721 [ 3326 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.575671 [ 2832 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.715493 [ 3328 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:50.875314 [ 2851 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.035093 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.316646 [ 2827 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.319273 [ 2848 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.434316 [ 2871 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.572294 [ 2985 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.578749 [ 3046 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.719229 [ 3000 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:51.878811 [ 2991 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.037905 [ 3037 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.322482 [ 2831 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.416459 [ 3281 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.438486 [ 2864 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.575592 [ 2858 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.581845 [ 2862 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.723074 [ 2865 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:52.882646 [ 2873 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.040478 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.326048 [ 2887 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.420558 [ 2885 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.441425 [ 2890 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.578932 [ 2923 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.585642 [ 3112 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.726797 [ 3199 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:53.886490 [ 2863 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.043513 [ 3305 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.329341 [ 2844 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.423994 [ 3157 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.444380 [ 3275 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.583878 [ 2897 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.589294 [ 3151 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.729851 [ 2846 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:54.895493 [ 3286 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.046665 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.332220 [ 2899 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.427328 [ 2874 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.448103 [ 2841 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.592802 [ 2903 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.596242 [ 2891 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.732586 [ 2889 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:55.898664 [ 2939 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.049574 [ 2876 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.334731 [ 2948 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.429789 [ 2934 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.451404 [ 2892 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.603628 [ 2967 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.604438 [ 2922 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.735530 [ 2977 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:56.901882 [ 2951 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.056349 [ 2973 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.337707 [ 2917 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.433396 [ 2962 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.454679 [ 2971 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.607382 [ 2982 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.611882 [ 2957 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.738580 [ 2988 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:57.905616 [ 2968 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.059197 [ 2984 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.341504 [ 3008 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.436073 [ 3010 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.457864 [ 2949 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.610921 [ 3057 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.615383 [ 3040 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.742240 [ 3062 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:58.908274 [ 3007 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.064275 [ 2997 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.344629 [ 3022 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.439206 [ 3033 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.460330 [ 3013 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.614266 [ 3017 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.618701 [ 3019 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.745452 [ 3085 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:40:59.910689 [ 3068 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.067188 [ 3052 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.353160 [ 3049 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.442993 [ 3087 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.466704 [ 3065 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.617816 [ 3067 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.622266 [ 3079 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.748153 [ 3055 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:00.913992 [ 3080 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.069823 [ 3063 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.360195 [ 3126 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.446295 [ 3108 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.470082 [ 3129 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.626160 [ 3103 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.687604 [ 3100 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.751590 [ 3073 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:01.916690 [ 3128 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.074963 [ 3118 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.372028 [ 3096 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.473769 [ 3059 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.504994 [ 3101 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.629497 [ 3119 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.696110 [ 3115 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.754804 [ 3141 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:02.919493 [ 3132 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.078656 [ 3086 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.376517 [ 3153 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.477195 [ 3155 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.508332 [ 3185 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.676519 [ 3142 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.699560 [ 3179 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.757876 [ 3146 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:03.922693 [ 3181 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.081319 [ 3111 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.379667 [ 2896 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.480749 [ 3264 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.511586 [ 3334 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.688677 [ 2983 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.703134 [ 3307 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.761123 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:04.926366 [ 3131 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.085429 [ 3192 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.384067 [ 3273 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.483712 [ 3206 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.516334 [ 3172 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.692312 [ 3110 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.711154 [ 3204 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.764937 [ 3190 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:05.929955 [ 3197 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:06.092545 [ 3226 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:06.391155 [ 3227 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:06.486383 [ 3242 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:06.592476 [ 3234 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:06.695803 [ 3205 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:06.714582 [ 3222 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:06.768514 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.076712 [ 3254 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.095160 [ 3238 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.394093 [ 3196 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.488737 [ 3256 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.595896 [ 3291 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.699138 [ 3195 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.717525 [ 3210 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:07.771582 [ 3269 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.079323 [ 3295 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.097790 [ 3278 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.396630 [ 3217 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.491435 [ 3134 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.601253 [ 2956 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.702290 [ 3274 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.724190 [ 3243 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:08.774830 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.084027 [ 3268 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.109772 [ 3293 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.456344 [ 3302 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.494015 [ 3319 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.604621 [ 2839 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.705319 [ 3323 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.727454 [ 3313 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:09.777917 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.087325 [ 3331 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.113231 [ 3287 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.459479 [ 3310 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.499029 [ 3266 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.607943 [ 2850 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.708833 [ 3324 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.730920 [ 3326 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:10.781288 [ 2823 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.090475 [ 2824 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.116226 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.163178 [ 2872 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.462744 [ 2843 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.501946 [ 2827 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.611169 [ 2830 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.712307 [ 2859 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.734938 [ 2842 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:11.794375 [ 2871 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.093529 [ 3000 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.119434 [ 3083 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.475097 [ 3038 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.505192 [ 3075 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.614864 [ 3186 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.717581 [ 2877 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.737490 [ 3023 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:12.797310 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.096886 [ 2862 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.123179 [ 2867 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.478895 [ 2901 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.516805 [ 2873 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.619182 [ 2855 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.720705 [ 2869 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.740613 [ 2894 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:13.800851 [ 2887 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.100857 [ 2919 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.133843 [ 3112 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.484110 [ 3305 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.519784 [ 3169 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.623661 [ 3262 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.723729 [ 2912 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.748655 [ 3157 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:14.804515 [ 2884 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.103482 [ 3284 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.136806 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.487005 [ 3286 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.522792 [ 3288 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.626772 [ 2878 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.726898 [ 2924 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.751629 [ 2947 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:15.806931 [ 2899 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.106264 [ 2930 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.139753 [ 2935 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.490945 [ 2931 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.526107 [ 2932 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.630689 [ 2876 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.741592 [ 2916 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.755223 [ 2970 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:16.816262 [ 2941 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.108913 [ 2922 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.142446 [ 2886 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.494354 [ 2969 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.600743 [ 2965 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.655622 [ 2938 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.763765 [ 2961 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.764231 [ 2962 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:17.819635 [ 2971 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.111886 [ 2979 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.145202 [ 2950 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.497687 [ 2995 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.603672 [ 2933 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.658931 [ 3008 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.767375 [ 3057 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.768141 [ 3040 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:18.823211 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.118064 [ 3030 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.149020 [ 3002 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.507277 [ 2980 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.607355 [ 2989 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.662193 [ 2992 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.775363 [ 3045 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.776602 [ 3013 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:19.826934 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.210745 [ 3024 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.210135 [ 3048 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.510919 [ 3039 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.611082 [ 3053 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.775519 [ 3078 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.783418 [ 2990 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.785303 [ 3077 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:20.830544 [ 3049 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.213796 [ 3055 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.297445 [ 3081 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.514032 [ 3063 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.614643 [ 3094 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.779669 [ 3104 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.786198 [ 3126 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.788486 [ 3108 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:21.833859 [ 3103 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.217215 [ 3118 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.300333 [ 3117 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.517589 [ 3113 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.618356 [ 3096 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.782890 [ 3119 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.789276 [ 3095 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.800343 [ 3115 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:22.837769 [ 3148 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.220101 [ 3132 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.303582 [ 3163 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.521000 [ 3160 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.621414 [ 3165 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.785688 [ 3136 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.792309 [ 3154 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.803523 [ 3153 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:23.841230 [ 3155 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.223313 [ 3180 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.307106 [ 3164 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.525189 [ 3178 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.624590 [ 3289 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.789261 [ 3082 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.795688 [ 2958 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.806807 [ 2896 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:24.845034 [ 2954 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.226536 [ 3173 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.310550 [ 3149 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.528611 [ 3201 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.627930 [ 3192 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.793728 [ 3187 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.798900 [ 3175 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.810361 [ 3273 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:25.848763 [ 3206 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.229606 [ 3226 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.313158 [ 3227 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.532632 [ 3242 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.631332 [ 3189 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.800205 [ 3234 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.802651 [ 3215 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.814617 [ 3200 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:26.861213 [ 3258 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.232681 [ 3216 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.316440 [ 3250 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.536081 [ 3214 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.634937 [ 3235 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.806394 [ 3254 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.822862 [ 3238 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.864571 [ 3207 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:27.870282 [ 3241 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.288925 [ 3233 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.323033 [ 3223 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.539232 [ 3210 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.638325 [ 3269 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.811010 [ 3295 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.827253 [ 3239 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.875235 [ 3278 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:28.876420 [ 3271 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.292026 [ 2978 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.326913 [ 3243 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.541632 [ 3261 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.623422 [ 3433 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {24310d89-f4f4-4694-b8de-dac7140488d3::202510_1_204_129}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.640546 [ 3283 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.814364 [ 3308 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.830782 [ 3302 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.880231 [ 3298 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:29.925770 [ 3319 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.390536 [ 3323 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.390664 [ 3313 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.544740 [ 3287 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.643582 [ 2847 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.817507 [ 3303 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.834344 [ 3191 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.883583 [ 2852 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:30.929056 [ 3266 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.393844 [ 3312 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.398473 [ 3318 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.548089 [ 2833 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.646331 [ 3325 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.855914 [ 2837 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.856048 [ 2849 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.886119 [ 2854 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:31.932233 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.396897 [ 2985 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.402717 [ 3106 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.556911 [ 3000 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.649666 [ 3083 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.859035 [ 3046 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.859220 [ 2991 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.888783 [ 3037 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:32.935572 [ 3021 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.400673 [ 2867 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.405769 [ 3056 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.560437 [ 2860 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.711335 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.862001 [ 2873 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.862695 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.907896 [ 3014 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:33.940973 [ 2909 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.403289 [ 3199 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.408977 [ 2926 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.564943 [ 2836 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.714310 [ 3001 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.866567 [ 3169 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.867712 [ 3262 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.911467 [ 3166 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:34.944319 [ 2904 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.406726 [ 3275 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.412295 [ 2897 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.568566 [ 3284 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.717009 [ 2879 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.870046 [ 3122 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.870934 [ 2875 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.914393 [ 3288 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:35.947783 [ 3270 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:36.410090 [ 2874 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:36.415459 [ 2841 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:36.571723 [ 2935 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:36.720315 [ 2903 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:36.873747 [ 2889 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:36.874142 [ 2931 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:36.917260 [ 2866 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.043890 [ 2932 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.413074 [ 2892 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.418620 [ 2922 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.575576 [ 2946 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.723726 [ 2951 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.877323 [ 2969 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.878116 [ 2974 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:37.920617 [ 2994 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.051021 [ 2938 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.417075 [ 2950 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.421734 [ 2996 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.579445 [ 2968 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.727303 [ 2995 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.881692 [ 2963 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.882133 [ 2987 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:38.924408 [ 3008 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.053692 [ 2976 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.419883 [ 3015 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.424473 [ 2997 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.587468 [ 2975 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.730971 [ 3025 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.885491 [ 2999 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.885700 [ 3042 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:39.927901 [ 2980 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.056683 [ 2989 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.423188 [ 3018 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.428050 [ 3017 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.595747 [ 3069 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.734272 [ 3005 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.888845 [ 3107 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.889453 [ 3053 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:40.932226 [ 3078 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.059733 [ 3049 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.426648 [ 3065 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.431285 [ 3098 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.599415 [ 3140 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.737447 [ 3102 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.891841 [ 3094 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.892583 [ 3099 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:41.935545 [ 3156 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.064571 [ 3097 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.430616 [ 3089 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.434796 [ 3070 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.602331 [ 3109 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.748142 [ 3072 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.895036 [ 3113 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.895835 [ 3124 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:42.939008 [ 3127 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.067831 [ 3139 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.434337 [ 3148 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.438174 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.606519 [ 3137 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.751616 [ 3152 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.898906 [ 3123 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.902435 [ 3086 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:43.942444 [ 3138 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.071124 [ 3155 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.437565 [ 3076 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.441226 [ 3146 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.612538 [ 3181 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.755016 [ 2959 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.901925 [ 3259 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.905077 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:44.945400 [ 2958 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.074084 [ 2954 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.440335 [ 3307 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.443887 [ 2925 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.615416 [ 3131 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.758028 [ 3176 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.904837 [ 3187 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.907374 [ 3175 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:45.948450 [ 3273 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.076762 [ 3167 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.443158 [ 3190 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.447062 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.618583 [ 3218 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.760699 [ 3225 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.907837 [ 3252 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.909608 [ 3247 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:46.951059 [ 3198 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.080075 [ 3177 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.445989 [ 3211 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.449549 [ 3216 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.621893 [ 3205 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.852632 [ 3250 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.910739 [ 3251 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.912557 [ 3214 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:47.953644 [ 3230 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.083381 [ 3241 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.449221 [ 3256 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.452181 [ 3256 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.625213 [ 3202 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.855818 [ 3272 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.914337 [ 3295 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.927057 [ 3239 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:48.956155 [ 3271 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.086337 [ 3294 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.453494 [ 3299 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.456592 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.633659 [ 2966 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.877665 [ 3296 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.917101 [ 3268 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.930297 [ 3261 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:49.958669 [ 3293 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.092705 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.457129 [ 3316 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.463325 [ 2839 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.637250 [ 3292 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.888308 [ 2840 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.919389 [ 2826 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.933284 [ 3315 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:50.961522 [ 3331 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.095638 [ 3303 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.460172 [ 3326 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.466145 [ 2825 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.640813 [ 2832 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.891743 [ 2822 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.922101 [ 3325 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.936763 [ 3332 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:51.964406 [ 2857 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.098862 [ 2835 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.462894 [ 2859 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.468784 [ 2868 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.643477 [ 3034 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.894301 [ 3037 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.925311 [ 3038 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.939619 [ 3075 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:52.967150 [ 3021 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:53.102257 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:53.465731 [ 2858 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:53.471891 [ 2862 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:53.646467 [ 2860 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:53.897355 [ 2909 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.021315 [ 2855 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.021523 [ 2894 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.021670 [ 2902 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.106271 [ 2910 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.475807 [ 3228 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.476909 [ 2863 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.655787 [ 3276 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:54.900361 [ 3001 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.024203 [ 2861 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.024681 [ 2904 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.025533 [ 2912 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.108953 [ 3157 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.479238 [ 2913 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.479918 [ 3012 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.658914 [ 3286 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:55.912734 [ 3051 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.027347 [ 2870 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.027906 [ 2924 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.028546 [ 2947 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.111820 [ 2907 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.483379 [ 2915 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.521455 [ 2935 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.661461 [ 2893 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:56.916016 [ 2970 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.030712 [ 2940 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.031377 [ 2948 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.032148 [ 2986 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.114529 [ 2921 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.486893 [ 2936 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.525044 [ 2951 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.664851 [ 2937 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:57.919805 [ 2911 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.035099 [ 2965 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.035886 [ 2961 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.117497 [ 2971 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.034110 [ 2938 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.490717 [ 2979 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.528375 [ 2996 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.668996 [ 3159 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:58.924233 [ 2995 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.038780 [ 3028 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.039097 [ 3009 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.118364 [ 2949 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.120808 [ 3040 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.125174 [ 2998 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.493959 [ 3003 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.532788 [ 3057 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.672952 [ 2972 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:41:59.928093 [ 3025 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:00.041002 [ 3031 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:00.046595 [ 2980 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:00.123430 [ 2989 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:00.128072 [ 3033 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:00.496370 [ 3019 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:00.536098 [ 3085 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:00.684678 [ 3048 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.012610 [ 3039 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.083548 [ 3053 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.084272 [ 3078 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.126499 [ 3087 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.130809 [ 3105 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.503498 [ 3140 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.539205 [ 3055 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:01.687584 [ 3080 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.015865 [ 3126 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.086729 [ 3129 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.087346 [ 3100 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.129895 [ 3114 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.133696 [ 3103 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.506452 [ 3070 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.542743 [ 3074 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:02.690537 [ 3128 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.020080 [ 3117 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.095447 [ 3113 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.090176 [ 3144 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.132951 [ 3096 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.203094 [ 3127 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.509605 [ 3101 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.546171 [ 3095 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:03.693758 [ 3084 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.098182 [ 3170 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.107880 [ 3086 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.111942 [ 3155 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.135903 [ 3165 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.205810 [ 3188 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.512702 [ 3219 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.548875 [ 3161 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:04.696817 [ 3180 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.100769 [ 3289 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.110686 [ 3111 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.114633 [ 3150 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.151940 [ 3082 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.208225 [ 2896 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.515759 [ 3334 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.552157 [ 2983 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:05.699817 [ 3279 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.103696 [ 3187 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.113581 [ 3175 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.117658 [ 3273 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.154718 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.210740 [ 3224 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.519216 [ 3206 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.555067 [ 3143 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:06.703147 [ 3190 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.106525 [ 3247 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.116309 [ 3198 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.120290 [ 3242 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.158405 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.213510 [ 3177 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.558159 [ 3240 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.593735 [ 3227 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.706189 [ 3250 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:07.714007 [ 3436 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3b7b9d5c-f30c-4cec-915e-651025b581f7::202510_1_200_40}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.109857 [ 3207 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.118854 [ 3241 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.122824 [ 3229 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.163601 [ 3238 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.216617 [ 3196 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.561212 [ 3223 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.606602 [ 3246 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:08.709871 [ 3210 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.116844 [ 3285 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.122136 [ 3280 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.125594 [ 3016 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.166477 [ 3294 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.227538 [ 3321 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.564076 [ 3306 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.612745 [ 3296 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:09.718232 [ 3261 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.120110 [ 3267 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.125221 [ 3302 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.134594 [ 3298 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.169244 [ 3319 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.236235 [ 3316 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.567295 [ 2840 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.615952 [ 3323 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:10.721448 [ 2826 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.123112 [ 3303 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.128373 [ 2847 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.138600 [ 3310 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.174280 [ 3287 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.239552 [ 2850 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.558425 [ 3433 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {85a939ff-1bdc-434a-abe3-c1f1ded4b10d::202510_1_221_89}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.570145 [ 2823 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.672453 [ 3318 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:11.767317 [ 2824 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.125745 [ 2872 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.131383 [ 2854 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.141583 [ 2843 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.179603 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.250153 [ 2848 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.572886 [ 2871 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.675915 [ 3043 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:12.770627 [ 3106 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.128179 [ 3046 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.134452 [ 2991 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.144259 [ 3037 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.182537 [ 3038 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.253493 [ 3021 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.576314 [ 3047 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.679258 [ 2864 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:13.774697 [ 2862 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.131960 [ 2887 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.137482 [ 2885 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.147111 [ 2890 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.185376 [ 2855 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.264367 [ 2902 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.579584 [ 3277 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.685894 [ 2919 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:14.778162 [ 3112 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.134559 [ 2945 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.144102 [ 3001 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.152677 [ 3169 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.197772 [ 2861 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.267074 [ 2912 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.582838 [ 2906 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.689704 [ 3151 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:15.781486 [ 3275 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.137201 [ 3286 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.147174 [ 3122 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.155272 [ 3051 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.199856 [ 2924 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.270162 [ 2899 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.586013 [ 2943 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.693086 [ 2874 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:16.785349 [ 2930 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.140244 [ 2931 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.150578 [ 2866 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.158335 [ 2876 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.202178 [ 2916 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.273542 [ 2932 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.593135 [ 2940 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.696402 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:17.817101 [ 2892 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.143146 [ 2951 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.153367 [ 2934 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.161123 [ 2974 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.205586 [ 2911 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.290570 [ 2965 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.596503 [ 2994 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.699418 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:18.820131 [ 2988 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.145843 [ 3010 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.156454 [ 3028 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.163880 [ 3009 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.254244 [ 3434 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2d6955c1-12a8-48e1-8c31-9252f5a6aaec::202510_1_176_52}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.303838 [ 3020 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.304339 [ 3062 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.599716 [ 3057 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.702325 [ 2972 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:19.823774 [ 2975 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.149265 [ 3030 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.159878 [ 3002 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.167413 [ 3042 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.307286 [ 2989 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.308091 [ 3033 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.602778 [ 3044 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.705461 [ 3019 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:20.827874 [ 3024 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.152735 [ 3048 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.163863 [ 3005 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.171086 [ 3052 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.310431 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.311098 [ 3078 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.615141 [ 3092 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.708408 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:21.860653 [ 3065 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.155618 [ 3102 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.173623 [ 3081 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.181786 [ 3116 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.313980 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.314157 [ 3099 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.617743 [ 3100 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.711631 [ 3114 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:22.863185 [ 3104 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.198742 [ 3117 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.198926 [ 3118 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.199095 [ 3072 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.317271 [ 3096 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.350832 [ 3059 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.620858 [ 3119 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.715038 [ 3148 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:23.870190 [ 3141 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.201939 [ 3153 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.202458 [ 3154 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.203340 [ 3136 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.320218 [ 3086 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.360853 [ 3165 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.632401 [ 3066 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.718399 [ 3163 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:24.873507 [ 3142 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.205815 [ 3181 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.206054 [ 3180 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.277775 [ 3164 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.322750 [ 3253 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.363544 [ 3194 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.636135 [ 3082 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.721137 [ 2954 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:25.877269 [ 2914 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.208664 [ 2983 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.209458 [ 3173 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.280827 [ 3131 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.325918 [ 3201 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.366081 [ 3176 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.639646 [ 3273 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.724291 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:26.881694 [ 3184 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.212073 [ 3168 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.215279 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.283988 [ 3130 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.330084 [ 3197 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.369116 [ 3110 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.642809 [ 3189 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.728110 [ 3177 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:27.885723 [ 3215 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.215230 [ 3249 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.218171 [ 3205 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.287422 [ 3231 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.333912 [ 3250 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.372657 [ 3244 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.645818 [ 3238 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.731302 [ 3265 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:28.888565 [ 3208 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.218540 [ 3269 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.230332 [ 3272 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.290598 [ 3295 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.337447 [ 3278 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.376159 [ 3271 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.648958 [ 3280 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.735183 [ 3134 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:29.891315 [ 3294 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.221974 [ 3311 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.233100 [ 3257 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.293626 [ 2978 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.340430 [ 3299 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.380555 [ 3290 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.651875 [ 3261 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.737615 [ 3329 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:30.894141 [ 3283 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.224688 [ 3297 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.236094 [ 3319 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.296172 [ 3316 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.343578 [ 2839 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.383178 [ 3314 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.654989 [ 3313 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.742761 [ 2826 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:31.898865 [ 3303 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.233068 [ 2850 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.238540 [ 2828 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.298836 [ 2838 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.346685 [ 2832 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.386317 [ 2823 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.658321 [ 3318 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.745800 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:32.901950 [ 3332 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.236637 [ 2842 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.241517 [ 2871 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.302082 [ 3043 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.349472 [ 2985 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.389635 [ 3106 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.661381 [ 3032 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.749052 [ 3046 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:33.905267 [ 3038 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.239970 [ 2858 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.244594 [ 2883 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.305366 [ 2860 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.354346 [ 3335 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.399669 [ 2909 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.664016 [ 2855 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.751828 [ 2888 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:34.908306 [ 2908 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.247455 [ 3228 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.300150 [ 2926 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.308260 [ 2863 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.360128 [ 2927 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.403110 [ 3001 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.688426 [ 3157 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.762492 [ 2884 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:35.911479 [ 2844 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.250572 [ 2882 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.304271 [ 3288 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.311582 [ 2879 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.362929 [ 2870 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.406161 [ 2947 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.691497 [ 2920 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.766105 [ 2878 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:36.915056 [ 2930 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.253780 [ 2876 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.307369 [ 2829 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.314841 [ 2918 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.365854 [ 2889 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.409588 [ 2939 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.695163 [ 2986 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.769061 [ 2921 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:37.918644 [ 2946 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.315055 [ 2937 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.315988 [ 2911 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.317774 [ 2936 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.391775 [ 2917 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.412071 [ 2938 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.698704 [ 2982 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.773462 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:38.922468 [ 2960 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.318240 [ 3009 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.324496 [ 2949 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.325121 [ 3040 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.394846 [ 3004 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.415314 [ 3020 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.704259 [ 3011 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.779283 [ 3057 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:39.925752 [ 2997 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.322390 [ 3064 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.327249 [ 3030 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.327560 [ 3002 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.330954 [ 3433 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {85a939ff-1bdc-434a-abe3-c1f1ded4b10d::202510_1_225_93}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.398994 [ 3007 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.417566 [ 2989 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.708036 [ 3045 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.783104 [ 3013 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:40.928930 [ 3018 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.326780 [ 3085 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.331388 [ 3048 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.331510 [ 3005 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.407955 [ 2990 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.420583 [ 3087 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.719694 [ 3049 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.786895 [ 3107 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:41.932506 [ 3098 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.330084 [ 3140 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.334633 [ 3125 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.338813 [ 3061 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.410634 [ 3156 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.423325 [ 3126 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.723050 [ 3114 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.790255 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:42.935555 [ 3089 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.336272 [ 3113 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.337856 [ 3096 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.341516 [ 3059 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.417782 [ 3139 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.426139 [ 3124 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.726949 [ 3147 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.793911 [ 3095 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:43.938883 [ 3084 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.339220 [ 3170 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.340511 [ 3086 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.343967 [ 3155 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.420248 [ 3066 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.530186 [ 3163 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.731286 [ 3142 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.796907 [ 3076 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:44.942799 [ 3161 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.341787 [ 3164 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.343074 [ 3253 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.346070 [ 2959 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.521967 [ 3194 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.533712 [ 3289 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.800283 [ 2958 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.829783 [ 3150 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:45.945592 [ 2955 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.344921 [ 3301 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.346028 [ 3176 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.349201 [ 3192 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.537160 [ 3273 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.601953 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.802980 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.832449 [ 3167 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:46.948260 [ 3190 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.348109 [ 3110 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.349121 [ 3252 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.351672 [ 3252 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.540196 [ 3177 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.605085 [ 3215 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.806259 [ 3200 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.836473 [ 3221 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:47.951398 [ 3240 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.351580 [ 3214 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.352575 [ 3235 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.355100 [ 3251 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.551847 [ 3241 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.608352 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.809726 [ 3208 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.840929 [ 3237 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:48.954795 [ 3195 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.355918 [ 3239 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.356183 [ 3271 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.358944 [ 3300 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.555552 [ 3134 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.611400 [ 3294 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.813495 [ 3213 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.844889 [ 2956 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:49.957551 [ 3311 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.359930 [ 2966 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.360252 [ 3306 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.361284 [ 3296 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.558502 [ 3283 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.613635 [ 3304 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.816670 [ 3317 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.847707 [ 3319 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:50.959994 [ 3316 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.362825 [ 3323 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.363924 [ 3313 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.364058 [ 2826 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.560894 [ 2845 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.703525 [ 3331 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.819551 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.850723 [ 3191 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:51.962580 [ 3266 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.366536 [ 3309 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.367368 [ 3312 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.367956 [ 3328 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.564363 [ 3332 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.706928 [ 2837 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.822558 [ 2854 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.853329 [ 2830 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:52.966712 [ 2859 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.369599 [ 3106 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.370366 [ 3034 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.371127 [ 3083 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.572750 [ 3037 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.709275 [ 2831 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.825325 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.856361 [ 3047 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:53.969533 [ 2853 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.373630 [ 2909 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.374485 [ 2895 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.381725 [ 2873 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.576009 [ 2890 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.712592 [ 2901 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.828524 [ 2910 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.946962 [ 2869 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:54.972562 [ 3277 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.377476 [ 2926 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.378185 [ 2863 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.412502 [ 3276 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.578463 [ 2904 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.715330 [ 2884 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.832177 [ 2844 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.976189 [ 2913 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:55.998804 [ 3275 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:56.380030 [ 2846 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:56.380706 [ 2875 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:56.415205 [ 3288 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:56.580937 [ 2924 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:56.718764 [ 2907 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:56.836159 [ 2943 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:56.979984 [ 2874 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.002260 [ 2935 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.383454 [ 2903 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.384442 [ 2876 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.425863 [ 2916 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.583498 [ 2889 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.722073 [ 2948 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.838794 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:57.983585 [ 2922 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.005379 [ 2946 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.386308 [ 2969 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.387296 [ 2936 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.429313 [ 2911 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.586153 [ 2971 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.725330 [ 2994 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.841553 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:58.987267 [ 2979 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.016992 [ 2960 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.389238 [ 2984 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.393022 [ 3010 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.432406 [ 3028 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.589083 [ 3040 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.728315 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.844132 [ 3006 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:42:59.991274 [ 3003 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.019331 [ 2972 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.392038 [ 3036 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.396115 [ 3064 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.435062 [ 3030 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.616508 [ 2989 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.731677 [ 3031 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.847678 [ 3033 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:00.998302 [ 2999 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:01.022296 [ 3044 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:01.394975 [ 3085 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:01.399621 [ 3090 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:01.438182 [ 3052 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:01.619261 [ 3087 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:01.769603 [ 3049 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:01.850564 [ 3077 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.005396 [ 3079 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.025275 [ 3065 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.398035 [ 3063 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.405703 [ 3055 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.441994 [ 3140 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.622598 [ 3156 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.772804 [ 3114 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:02.853282 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.007936 [ 3104 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.027920 [ 3089 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.402062 [ 3109 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.445160 [ 3117 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.496503 [ 3072 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.626057 [ 3096 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.776326 [ 3088 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:03.856238 [ 3147 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.011190 [ 3095 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.031153 [ 3148 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.407159 [ 3154 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.448888 [ 3136 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.499898 [ 3086 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.629708 [ 3165 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.779193 [ 3188 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:04.859272 [ 3076 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.019040 [ 3181 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.034873 [ 3180 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.410779 [ 3178 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.452388 [ 3289 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.503236 [ 3111 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.633331 [ 3082 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.782514 [ 3150 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:05.863740 [ 2896 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.021968 [ 3264 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.038025 [ 2925 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.415762 [ 3279 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.455240 [ 3201 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.506091 [ 3301 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.636884 [ 3175 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.786243 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:06.866994 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.024931 [ 3224 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.041264 [ 3190 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.418908 [ 3197 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.458862 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.509245 [ 3143 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.640430 [ 3110 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.789524 [ 3252 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:07.869919 [ 3198 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.077452 [ 3260 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.078509 [ 3215 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.421783 [ 3222 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.461629 [ 3216 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.512208 [ 3211 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.650926 [ 3249 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.792952 [ 3235 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:08.872861 [ 3207 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.080640 [ 3256 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.081309 [ 3195 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.426200 [ 3272 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.465084 [ 3295 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.515749 [ 3278 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.654722 [ 3300 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.796319 [ 3285 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:09.876449 [ 3280 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.083300 [ 3294 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.084235 [ 3217 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.429858 [ 3257 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.477977 [ 2978 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.554650 [ 3243 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.658019 [ 2966 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.799431 [ 3261 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:10.879780 [ 3182 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.086711 [ 3267 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.087070 [ 3302 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.433179 [ 3297 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.531961 [ 3263 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.557474 [ 3292 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.661449 [ 2839 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.802503 [ 2840 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:11.883176 [ 3313 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.089495 [ 3310 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.090063 [ 3322 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.436326 [ 2850 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.535494 [ 2838 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.636897 [ 2823 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.664777 [ 2832 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.806901 [ 3328 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:12.885986 [ 2833 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.092128 [ 2856 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.093010 [ 2849 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.439880 [ 2848 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.538753 [ 2835 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.640091 [ 2842 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.668131 [ 2871 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.810746 [ 3043 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:13.889490 [ 2834 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.095173 [ 3038 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.095741 [ 2831 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.444106 [ 2881 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.543953 [ 2867 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.643225 [ 2858 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.670877 [ 2860 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.838340 [ 3035 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:14.892545 [ 3335 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.098351 [ 2873 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.099330 [ 3014 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.449128 [ 2900 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.547086 [ 2902 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.673912 [ 2888 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.692465 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.842308 [ 2869 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:15.895845 [ 2908 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.101616 [ 2863 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.103435 [ 3001 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.452736 [ 3166 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.550641 [ 2836 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.687499 [ 2897 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.695808 [ 3262 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.845084 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:16.899312 [ 3012 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.104307 [ 3275 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.106020 [ 2846 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.458468 [ 2947 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.553682 [ 2899 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.690968 [ 2907 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.699322 [ 2920 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.848062 [ 2891 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:17.907097 [ 2893 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.107843 [ 2931 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.108841 [ 2866 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.461683 [ 2970 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.556759 [ 2941 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.694649 [ 2921 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.703043 [ 2892 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.851907 [ 2942 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:18.910157 [ 2934 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.115981 [ 2937 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.116663 [ 2911 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.466857 [ 2953 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.560025 [ 2957 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.698294 [ 2988 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.715794 [ 2979 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.858019 [ 3159 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:19.913451 [ 2993 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.120009 [ 2996 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.120482 [ 2933 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.470112 [ 2998 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.563827 [ 3071 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.701870 [ 3060 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.719270 [ 3003 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.861199 [ 3026 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:20.917182 [ 3041 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.123387 [ 3036 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.123712 [ 3025 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.473026 [ 2980 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.567420 [ 3031 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.705021 [ 3022 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.722049 [ 2999 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.864564 [ 3044 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:21.920575 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.127074 [ 3069 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.127817 [ 3024 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.476159 [ 3048 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.572042 [ 3052 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.708490 [ 3078 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.725167 [ 3053 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.868251 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:22.924364 [ 3092 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.130428 [ 3091 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.131110 [ 3067 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.479486 [ 3063 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.575224 [ 3140 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.711899 [ 3055 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.728859 [ 3061 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.871693 [ 3094 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:23.927782 [ 3126 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.190650 [ 3072 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.191165 [ 3058 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.483539 [ 3124 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.578026 [ 3127 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.715341 [ 3119 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.732437 [ 3147 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.875195 [ 3115 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:24.932259 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.193419 [ 3121 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.194144 [ 3154 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.487261 [ 3136 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.582192 [ 3170 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.718910 [ 3155 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.736701 [ 3165 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.878741 [ 3163 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:25.936018 [ 3188 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.196531 [ 3161 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.197922 [ 3179 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.490630 [ 3219 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.585406 [ 3289 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.722730 [ 3111 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.740438 [ 3259 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.882094 [ 2954 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:26.939618 [ 3150 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.203700 [ 3264 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.204146 [ 2955 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.495165 [ 3279 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.588920 [ 3301 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.726370 [ 3187 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.744037 [ 3175 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.890067 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:27.942780 [ 3167 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.206594 [ 3206 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.207126 [ 3168 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.498024 [ 3197 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.592076 [ 3226 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.729773 [ 3242 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.748148 [ 3247 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.892762 [ 3260 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:28.945501 [ 3225 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.209845 [ 3205 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.210909 [ 3231 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.501510 [ 3251 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.595520 [ 3230 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.732763 [ 3236 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.751534 [ 3265 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.895588 [ 3208 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:29.948828 [ 3254 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.213116 [ 3202 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.214251 [ 3210 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.504907 [ 3291 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.599081 [ 3278 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.740696 [ 3285 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.754869 [ 3280 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.898435 [ 3134 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:30.952017 [ 3321 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.282812 [ 3299 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.286975 [ 3274 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.507183 [ 3290 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.602252 [ 2966 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.743788 [ 3320 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.761525 [ 3268 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.901930 [ 3298 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:31.954719 [ 3304 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.286321 [ 3263 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.290434 [ 3292 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.510119 [ 2840 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.606015 [ 3313 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.746462 [ 2826 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.773011 [ 2845 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.905405 [ 3310 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:32.957790 [ 3322 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.289008 [ 2838 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.293562 [ 2828 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.516232 [ 3318 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.609768 [ 2824 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.750355 [ 2837 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.776435 [ 2856 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.909131 [ 2851 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:33.961195 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.292055 [ 3029 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.296173 [ 2985 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.524006 [ 3046 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.613139 [ 2991 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.753315 [ 2877 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.782245 [ 3034 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.912804 [ 3027 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:34.967195 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.295253 [ 2867 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.299118 [ 3056 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.526889 [ 2880 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.616954 [ 3035 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.756683 [ 2895 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.785555 [ 2873 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.915392 [ 2890 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:35.970483 [ 2900 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.298732 [ 2910 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.302271 [ 2928 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.530103 [ 3112 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.655783 [ 2923 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.759855 [ 2919 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.788726 [ 2863 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.918086 [ 2861 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.920749 [ 3446 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_372_402_6}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:36.973243 [ 3166 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.302071 [ 2884 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.305767 [ 2844 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.536593 [ 2913 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.659039 [ 2906 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.763147 [ 3284 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.792131 [ 3286 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.920887 [ 2846 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:37.976657 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.235306 [ 2924 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.305376 [ 2947 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.308938 [ 2907 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.539678 [ 2915 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.662455 [ 2866 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.766762 [ 2916 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.795447 [ 2935 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.924562 [ 2918 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:38.980544 [ 2889 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.309213 [ 2886 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.312293 [ 2977 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.545240 [ 2961 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.666165 [ 2951 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.771146 [ 2938 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.799139 [ 2971 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.934326 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:39.986360 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.373871 [ 2964 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.374907 [ 2995 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.548450 [ 2933 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.669451 [ 2984 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.774590 [ 2950 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.802920 [ 3028 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.938573 [ 2998 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:40.989766 [ 3004 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.378810 [ 2997 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.379591 [ 3026 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.551558 [ 3041 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.672288 [ 3036 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.777712 [ 3025 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.806541 [ 3064 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.942484 [ 3042 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:41.992472 [ 2989 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.381479 [ 2999 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.423102 [ 2992 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.554692 [ 3018 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.682204 [ 3024 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.781019 [ 3068 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.813832 [ 3050 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.949257 [ 3090 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:42.995121 [ 3054 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.385053 [ 3049 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.426568 [ 3092 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.560666 [ 3079 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.686524 [ 3098 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.790878 [ 3102 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.817934 [ 3077 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.953342 [ 3081 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:43.998701 [ 3063 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:44.388276 [ 3089 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:44.430069 [ 3108 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:44.564952 [ 3114 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:44.689395 [ 3109 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:44.793881 [ 3118 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:44.821339 [ 3072 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:44.957218 [ 3133 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.002451 [ 3139 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.391628 [ 3095 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.433592 [ 3115 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.568164 [ 3141 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.692799 [ 3123 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.797301 [ 3160 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.824794 [ 3101 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:45.961161 [ 3121 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.006969 [ 3145 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.394922 [ 3155 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.436838 [ 3165 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.572418 [ 3066 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.696022 [ 3188 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.800338 [ 3076 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.827739 [ 3135 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:46.964631 [ 3179 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.013913 [ 3180 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.397411 [ 3259 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.439972 [ 3082 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.576153 [ 2958 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.699150 [ 2955 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.802751 [ 2914 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.830805 [ 2925 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:47.968807 [ 2983 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.017084 [ 3149 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.400240 [ 3172 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.442739 [ 3224 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.579491 [ 3171 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.702840 [ 3168 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.806178 [ 3218 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.834001 [ 3193 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:48.972383 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.020060 [ 3110 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.404010 [ 3221 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.445823 [ 3227 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.584192 [ 3211 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.706816 [ 3258 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.809655 [ 3205 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.837617 [ 3231 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:49.976010 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.022600 [ 3235 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.407653 [ 3265 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.454539 [ 3238 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.593660 [ 3220 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.710343 [ 3195 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.813372 [ 3246 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.840899 [ 3196 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:50.979410 [ 3256 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.025644 [ 3209 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.411431 [ 3278 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.457796 [ 3271 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.598119 [ 3300 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.714019 [ 3280 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.816997 [ 3016 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.844298 [ 3217 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:51.983410 [ 3321 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.029160 [ 3311 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.414940 [ 3255 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.461203 [ 2966 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.601634 [ 3306 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.718171 [ 3261 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.828494 [ 3329 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.848297 [ 3182 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:52.987110 [ 3302 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.032579 [ 3304 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.418362 [ 3263 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.464824 [ 3292 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.604999 [ 3282 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.721284 [ 3313 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.832175 [ 3315 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.851609 [ 2847 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:53.990824 [ 3303 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.035475 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.421566 [ 3312 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.468955 [ 3328 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.608363 [ 3318 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.724720 [ 2824 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.835336 [ 2856 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.854824 [ 2849 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:54.993936 [ 2872 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.038250 [ 2843 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.424202 [ 2827 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.472036 [ 3043 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.612993 [ 2985 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.728716 [ 3083 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.838831 [ 3046 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.858078 [ 3037 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:55.997400 [ 2877 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:56.041446 [ 3034 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:56.427347 [ 3047 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:56.475216 [ 2853 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:56.616752 [ 3056 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:56.731792 [ 2883 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:56.841439 [ 2880 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:56.863998 [ 3035 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.000196 [ 3335 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.043943 [ 3014 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.430565 [ 2909 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.478823 [ 2855 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.620332 [ 2902 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.735117 [ 2901 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.844739 [ 2869 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:57.867173 [ 2908 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.003851 [ 2919 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.046872 [ 3228 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.164481 [ 3434 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_372_407_7}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=18, 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c76fc0b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c76a418 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c769d8b 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) @ 0x000000002c7b8f63 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&&) @ 0x000000002c5e0dc1 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 @ 0x000000002c5db0d7 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) @ 0x000000002c816490 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&) @ 0x000000002c81d36f 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) @ 0x000000002c81a972 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3e7119 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e05b6 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3ec839 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c3f949e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc398a0 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 26. asan_thread_start(void*) @ 0x000000000aa45059 27. ? @ 0x00007f2f94fabac3 28. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.433630 [ 2861 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.482314 [ 3305 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.623702 [ 2884 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.738618 [ 2897 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.848725 [ 3151 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:58.870508 [ 2906 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.006712 [ 3275 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.049801 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.437106 [ 2899 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.485686 [ 3270 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.627566 [ 2915 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.741525 [ 2931 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.851925 [ 2943 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:43:59.873269 [ 2916 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.009695 [ 2829 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.052558 [ 2898 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.474504 [ 2986 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.489249 [ 2921 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.630332 [ 2946 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.837029 [ 2934 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.855110 [ 2974 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:00.876484 [ 2886 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.013254 [ 2967 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.055380 [ 2936 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.478041 [ 2962 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.492750 [ 2938 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.633771 [ 2957 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.840162 [ 2993 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.858448 [ 2964 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:01.880243 [ 2995 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.016332 [ 3008 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.059111 [ 2984 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.481654 [ 3062 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.496399 [ 3006 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.637134 [ 3003 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.842842 [ 3036 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.866677 [ 3025 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:02.882992 [ 3064 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.020737 [ 2975 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.061747 [ 3002 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.484810 [ 2999 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.499179 [ 2992 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.639565 [ 3024 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.845180 [ 3048 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.869249 [ 3085 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:03.889851 [ 3090 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.035708 [ 3087 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.064414 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.491516 [ 3081 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.551221 [ 3116 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.643526 [ 3061 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.848402 [ 3156 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.872549 [ 3100 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:04.893228 [ 3129 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.067327 [ 3104 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.089842 [ 3093 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.495055 [ 3074 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.554789 [ 3070 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.646567 [ 3118 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.851673 [ 3113 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.876018 [ 3133 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:05.903280 [ 3096 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.070386 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.095686 [ 3119 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.498785 [ 3152 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.558620 [ 3101 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.649456 [ 3138 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.856027 [ 3145 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.879441 [ 3137 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:06.906841 [ 3154 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.073205 [ 3086 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.098786 [ 3155 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.502481 [ 3076 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.562088 [ 3161 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.652878 [ 3179 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.859353 [ 3219 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.883476 [ 3253 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:07.910250 [ 2959 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.076199 [ 3111 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.101689 [ 3194 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.505578 [ 2955 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.565671 [ 3232 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.656374 [ 3149 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.863213 [ 3279 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.886715 [ 3131 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:08.914017 [ 3301 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.078389 [ 3192 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.104048 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.516522 [ 3168 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.569243 [ 3130 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.660000 [ 3204 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.866562 [ 3203 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.890334 [ 3252 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:09.917191 [ 3189 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.089493 [ 3177 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.123927 [ 3200 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.520262 [ 3240 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.579818 [ 3211 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.663342 [ 3231 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.869822 [ 3235 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.893971 [ 3250 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:10.920507 [ 3207 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.092105 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.126539 [ 3220 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.523577 [ 3246 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.591143 [ 3196 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.666898 [ 3256 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.873361 [ 3233 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.897601 [ 3272 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:11.927464 [ 3295 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.095682 [ 3271 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.129812 [ 3239 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.527036 [ 3294 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.594912 [ 3217 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.671096 [ 3213 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.876103 [ 3245 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.900725 [ 3299 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:12.930908 [ 3243 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.099385 [ 3255 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.132707 [ 3306 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.530359 [ 3329 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.660980 [ 3267 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.674364 [ 3317 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.904449 [ 3297 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.933504 [ 3308 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:13.935089 [ 3298 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.102958 [ 3314 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.135533 [ 3330 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.533827 [ 3310 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.664274 [ 3331 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.677676 [ 3266 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.907858 [ 3326 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.937355 [ 2838 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:14.938608 [ 2825 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.106173 [ 2823 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.138702 [ 2832 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.537280 [ 2857 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.667840 [ 2849 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.681270 [ 2851 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.920467 [ 2859 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.941611 [ 3332 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:15.942499 [ 2835 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.109772 [ 2827 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.142590 [ 2834 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.600072 [ 3000 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.671533 [ 3046 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.685073 [ 3037 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.966270 [ 2877 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.967098 [ 3034 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:16.971426 [ 2831 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.113016 [ 3075 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.146101 [ 3186 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.646143 [ 2880 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.675613 [ 3035 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.688087 [ 2865 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.970323 [ 2895 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.970709 [ 2909 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:17.974902 [ 2855 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.120321 [ 2905 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.148991 [ 2901 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.649406 [ 3228 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.679226 [ 3001 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.691142 [ 3276 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.973865 [ 3199 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.974635 [ 2945 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:18.978337 [ 2861 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:19.124039 [ 2906 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:19.152260 [ 3275 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:19.651823 [ 2870 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:19.682280 [ 3288 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:19.697388 [ 3286 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:19.978199 [ 2899 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:19.981054 [ 2920 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.021127 [ 2874 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.127948 [ 2893 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.155229 [ 2952 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.654778 [ 2916 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.686102 [ 2876 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.700775 [ 2841 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.981575 [ 2986 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:20.984509 [ 2921 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.024554 [ 2939 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.131009 [ 2934 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.157625 [ 2974 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.657557 [ 2911 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.688739 [ 2961 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.703722 [ 2917 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.984685 [ 2929 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:21.988051 [ 2994 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.027871 [ 2982 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.134073 [ 2988 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.160307 [ 2944 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.661039 [ 2968 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.742813 [ 3008 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.743639 [ 2933 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.988027 [ 2987 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:22.991193 [ 2996 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.030675 [ 2949 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.137516 [ 3071 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.163048 [ 3004 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.664166 [ 3011 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.746118 [ 3057 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.747055 [ 2972 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.992325 [ 3015 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:23.994857 [ 3025 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.033827 [ 2975 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.140808 [ 2980 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.166533 [ 3022 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.669027 [ 3018 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.749073 [ 3069 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.749896 [ 3024 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.996428 [ 3048 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:24.998424 [ 3085 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:25.045628 [ 3090 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:25.143674 [ 3078 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:25.169765 [ 3053 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:25.672027 [ 3067 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:25.752645 [ 3098 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:25.753665 [ 3039 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:25.999937 [ 3081 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:26.002061 [ 3063 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:26.048627 [ 3061 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:26.146782 [ 3099 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:26.173140 [ 3100 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:26.675495 [ 3093 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:26.756256 [ 3073 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:26.757329 [ 3097 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.007402 [ 3118 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.007889 [ 3072 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.051585 [ 3058 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.150248 [ 3144 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.176243 [ 3133 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.679409 [ 3115 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.760545 [ 3095 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:27.761591 [ 3120 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.011457 [ 3152 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.019553 [ 3123 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.054424 [ 3160 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.152944 [ 3132 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.178797 [ 3121 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.682865 [ 3086 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.763853 [ 3165 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:28.764947 [ 3185 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.014229 [ 3163 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.022519 [ 3142 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.057812 [ 3076 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.155274 [ 3219 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.181379 [ 2959 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.687057 [ 2958 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.817446 [ 2914 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:29.818068 [ 3232 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.017465 [ 2983 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.025998 [ 3149 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.061482 [ 3334 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.158102 [ 3176 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.184566 [ 3175 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.690569 [ 3167 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.821336 [ 3171 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:30.822288 [ 3224 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.020834 [ 3168 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.028966 [ 3130 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.064454 [ 3218 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.160924 [ 3204 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.187218 [ 3203 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.694093 [ 3198 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.825191 [ 3226 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:31.826169 [ 3177 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.023743 [ 3200 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.031653 [ 3222 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.067194 [ 3227 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.163403 [ 3216 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.190025 [ 3258 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.697586 [ 3207 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.828742 [ 3229 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:32.829881 [ 3238 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.026917 [ 3254 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.034316 [ 3223 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.069970 [ 3246 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.165427 [ 3196 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.196473 [ 3209 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.700879 [ 3295 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.894689 [ 2981 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:33.895401 [ 3278 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.035751 [ 3134 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.037840 [ 3321 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.073002 [ 3257 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.168251 [ 3243 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.199682 [ 3306 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.705520 [ 3182 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.899636 [ 3296 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:34.907978 [ 3302 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.038758 [ 3297 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.042130 [ 3297 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.075912 [ 3283 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.171555 [ 3292 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.202880 [ 3314 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.708470 [ 3319 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.905684 [ 3310 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:35.911459 [ 3322 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.042138 [ 3287 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.045352 [ 3287 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.079188 [ 3266 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.174590 [ 2850 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.206581 [ 3326 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.712034 [ 3309 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.909230 [ 2822 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:36.914997 [ 3325 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.045298 [ 2857 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.048460 [ 2857 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.082821 [ 2872 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.178716 [ 2848 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.210069 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.715813 [ 2842 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.912823 [ 3106 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:37.918378 [ 3083 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.048350 [ 2991 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.051567 [ 3021 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.085682 [ 3038 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.181805 [ 3023 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.213032 [ 3075 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.719224 [ 2858 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.916482 [ 2880 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:38.921651 [ 2860 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.051546 [ 3335 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.054466 [ 3335 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.168961 [ 2887 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.184801 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.215573 [ 2901 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.746784 [ 3112 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.920867 [ 3001 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:39.924950 [ 3276 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.055027 [ 3169 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.057147 [ 2945 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.176372 [ 3166 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.187939 [ 3157 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.218470 [ 3199 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.749764 [ 3284 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.924265 [ 2882 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:40.928090 [ 3051 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.058470 [ 3286 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.060346 [ 2924 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.179557 [ 2899 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.191336 [ 2920 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.221686 [ 2874 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.753467 [ 2866 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.927451 [ 2841 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:41.930754 [ 2829 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.061515 [ 2889 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.063460 [ 2932 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.182639 [ 2940 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.195796 [ 2935 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.231014 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.757179 [ 2969 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.930974 [ 2961 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:42.933929 [ 2917 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.064842 [ 2962 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.070301 [ 2971 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.186392 [ 2982 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.200000 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.234656 [ 2979 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.761233 [ 3008 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.934753 [ 2963 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:43.940804 [ 2963 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.068085 [ 2950 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.073533 [ 2987 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.195750 [ 3060 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.203062 [ 3020 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.238077 [ 3011 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.766019 [ 3015 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.938645 [ 3007 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:44.944567 [ 2980 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.071176 [ 3031 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.076639 [ 3064 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.198738 [ 3044 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.211770 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.241461 [ 3019 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.769943 [ 3048 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.942143 [ 3054 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:45.947745 [ 3068 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.074933 [ 3005 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.079858 [ 3087 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.201656 [ 3092 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.214641 [ 3079 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.247356 [ 3107 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.773940 [ 3140 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.945538 [ 3094 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:46.951367 [ 3099 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.083032 [ 3116 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.086332 [ 3100 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.206057 [ 3125 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.218329 [ 3103 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.257552 [ 3104 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.778872 [ 3074 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.949266 [ 3118 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:47.959588 [ 3072 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.128680 [ 3113 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.128875 [ 3096 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.209290 [ 3124 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.221933 [ 3127 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.260879 [ 3147 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.783868 [ 3162 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.958513 [ 3138 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:48.978147 [ 3121 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.132297 [ 3137 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.132731 [ 3153 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.212014 [ 3066 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.225534 [ 3170 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.264168 [ 3183 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.789596 [ 3164 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.964476 [ 2959 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:49.981715 [ 3146 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.136353 [ 3111 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.136756 [ 3194 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.215254 [ 3082 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.228580 [ 3150 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.267489 [ 3264 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.793413 [ 3149 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.967533 [ 3173 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:50.985317 [ 3301 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.139618 [ 3175 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.141470 [ 3192 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.218729 [ 3201 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.231581 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.270885 [ 3167 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.798274 [ 3193 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.970979 [ 3197 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:51.988945 [ 3252 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.142960 [ 3215 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.144562 [ 3198 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.221879 [ 3226 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.239646 [ 3177 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.274014 [ 3234 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.802042 [ 3244 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.983790 [ 3207 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:52.992301 [ 3236 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.145982 [ 3230 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.147696 [ 3220 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.232898 [ 3237 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.243246 [ 3223 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.277081 [ 3195 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.806084 [ 3233 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.987405 [ 3210 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:53.996367 [ 3291 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.238251 [ 3016 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.242252 [ 3217 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.247247 [ 3321 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.280293 [ 3299 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.294783 [ 3134 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.815559 [ 3306 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.991282 [ 3290 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:54.999970 [ 3261 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:55.241792 [ 3267 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:55.246036 [ 3296 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:55.255509 [ 3302 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:55.286104 [ 3317 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:55.298697 [ 3308 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:55.818648 [ 3330 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.004021 [ 2826 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.021666 [ 2847 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.245743 [ 3287 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.249398 [ 3191 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.258929 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.294733 [ 2845 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.303106 [ 2850 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:56.822256 [ 3324 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.007393 [ 2833 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.029934 [ 3325 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.249256 [ 2849 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.255512 [ 2851 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.262850 [ 2872 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.298030 [ 2830 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.306989 [ 2824 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:57.825626 [ 2868 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.010930 [ 2842 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.033795 [ 3043 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.257309 [ 3032 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.259825 [ 3037 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.266940 [ 3021 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.301991 [ 3038 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.310401 [ 3000 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:58.829275 [ 3027 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.014041 [ 3281 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.037256 [ 2853 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.261053 [ 3014 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.264955 [ 2890 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.279138 [ 2887 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.305833 [ 2895 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.314262 [ 2909 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:44:59.833780 [ 2901 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.018345 [ 3277 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.041111 [ 2928 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.264782 [ 2863 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.269015 [ 2919 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.282719 [ 2926 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.309916 [ 3001 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.327756 [ 3276 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:00.837713 [ 2923 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.021953 [ 3151 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.044457 [ 3262 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.268421 [ 2912 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.272487 [ 2913 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.285753 [ 3284 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.313664 [ 2875 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.331233 [ 2882 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:01.841335 [ 2920 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.025453 [ 2915 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.048131 [ 2952 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.272376 [ 2931 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.276749 [ 2943 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.288617 [ 2916 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.316971 [ 2841 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.334847 [ 2829 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:02.845597 [ 2935 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.051993 [ 2986 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.087323 [ 2921 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.143351 [ 2946 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.275632 [ 2942 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.280659 [ 2922 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.292581 [ 2974 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.325086 [ 2886 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.338332 [ 2977 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:03.849247 [ 2957 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.077830 [ 2993 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.090411 [ 3159 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.278607 [ 2963 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.283955 [ 2950 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.296022 [ 2987 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.328570 [ 3028 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.342557 [ 2949 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:04.852882 [ 3004 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.081359 [ 2976 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.094175 [ 3003 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.282021 [ 2997 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.287274 [ 3026 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.299990 [ 3041 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.332156 [ 3036 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.346356 [ 2975 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:05.857278 [ 3031 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.084341 [ 2992 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.097073 [ 3044 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.285586 [ 3013 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.290519 [ 3017 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.303505 [ 3050 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.342809 [ 3048 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.349828 [ 3085 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:06.860468 [ 3087 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.087579 [ 3079 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.099782 [ 3107 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.288759 [ 3098 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.293925 [ 3039 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.306828 [ 3102 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.346147 [ 3081 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.352620 [ 3140 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:07.934128 [ 3099 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.091441 [ 3103 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.102961 [ 3104 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.292579 [ 3089 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.297425 [ 3108 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.311788 [ 3074 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.349334 [ 3118 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.355518 [ 3058 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:08.938346 [ 3124 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.094999 [ 3119 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.105938 [ 3095 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.296160 [ 3141 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.303301 [ 3145 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.316082 [ 3136 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.352739 [ 3101 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.359048 [ 3137 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:09.942532 [ 3170 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.098413 [ 3142 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.108579 [ 3076 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.299925 [ 3219 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.314952 [ 3179 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.327134 [ 3253 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.356363 [ 3146 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.362698 [ 3111 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:10.955073 [ 3150 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.101282 [ 2914 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.111928 [ 2954 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.304162 [ 2983 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.318359 [ 3149 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.330974 [ 3334 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.359926 [ 3173 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.366093 [ 3301 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:11.958364 [ 3307 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.114255 [ 3184 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.116552 [ 3206 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.307921 [ 3252 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.322343 [ 3143 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.334685 [ 3189 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.363298 [ 3110 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.369826 [ 3215 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:12.969415 [ 3200 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.117373 [ 3216 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.119454 [ 3240 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.316484 [ 3231 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.325884 [ 3244 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.346749 [ 3235 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.366526 [ 3249 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.373304 [ 3250 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:13.972972 [ 3237 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.119972 [ 3246 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.122173 [ 3196 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.320313 [ 3291 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.329545 [ 3271 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.370950 [ 3295 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.377753 [ 3278 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.417679 [ 3239 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:14.981312 [ 3299 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:15.123241 [ 3257 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:15.126848 [ 3306 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:15.324397 [ 3248 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:15.333485 [ 3290 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:15.374719 [ 3261 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:15.381922 [ 3293 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:15.421378 [ 3182 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.034723 [ 3316 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.127061 [ 3330 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.129880 [ 3304 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.328527 [ 3313 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.337876 [ 3319 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.378429 [ 2826 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.385800 [ 2847 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:16.424844 [ 3322 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.037897 [ 2838 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.133530 [ 2828 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.133642 [ 2823 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.331814 [ 3325 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.340846 [ 2856 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.381943 [ 2857 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.389274 [ 3318 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:17.428426 [ 2849 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.041189 [ 2830 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.136810 [ 2859 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.137558 [ 3332 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.341095 [ 2985 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.344343 [ 2842 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.385492 [ 3043 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.392698 [ 3106 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:18.431687 [ 2871 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.044549 [ 3186 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.140491 [ 2881 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.140572 [ 3281 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.345000 [ 2860 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.347577 [ 2865 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.388707 [ 2890 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.396280 [ 3335 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:19.435077 [ 3014 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.047775 [ 2900 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.144133 [ 2928 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.145024 [ 2869 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.348581 [ 2919 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.350633 [ 2926 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.392268 [ 3001 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.399523 [ 3276 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:20.439013 [ 2927 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.051884 [ 2904 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.148089 [ 3151 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.148706 [ 3262 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.351896 [ 2912 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.353986 [ 2846 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.395939 [ 3284 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.403109 [ 3275 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:21.442156 [ 2882 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.056575 [ 2878 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.151998 [ 2874 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.153054 [ 2893 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.357677 [ 2931 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.359056 [ 2943 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.399480 [ 2916 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.407197 [ 2889 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:22.445242 [ 2941 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.059629 [ 2934 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.155766 [ 2922 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.156986 [ 2974 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.361216 [ 2977 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.362420 [ 2967 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.402598 [ 2911 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.409627 [ 2937 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:23.448336 [ 2961 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.063541 [ 2982 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.159113 [ 2944 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.160036 [ 2953 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.364744 [ 3028 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.366237 [ 2996 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.407295 [ 2998 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.412486 [ 3071 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:24.451777 [ 3040 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.066919 [ 3011 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.162708 [ 2997 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.163623 [ 3026 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.368354 [ 3015 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.369707 [ 3002 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.410919 [ 3042 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.416455 [ 3007 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:25.540805 [ 3030 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.070307 [ 3069 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.166506 [ 3033 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.166828 [ 3013 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.372299 [ 3048 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.372761 [ 3085 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.423797 [ 3052 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.424527 [ 3054 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:26.543497 [ 2990 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.073238 [ 3092 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.170152 [ 3039 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.170928 [ 3091 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.380321 [ 3081 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.407818 [ 3080 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.428927 [ 3055 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.429826 [ 3061 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:27.546425 [ 3116 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.076603 [ 3089 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.173347 [ 3070 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.173527 [ 3156 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.383830 [ 3058 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.411951 [ 3072 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.433527 [ 3133 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.438486 [ 3113 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:28.550293 [ 3128 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.079665 [ 3148 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.176811 [ 3084 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.177873 [ 3152 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.387093 [ 3145 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.419716 [ 3136 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.442000 [ 3101 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.475429 [ 3153 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:29.554102 [ 3154 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.082885 [ 3183 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.180764 [ 3164 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.181594 [ 3219 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.390066 [ 3146 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.423298 [ 3111 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.537542 [ 3181 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.538285 [ 3289 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:30.557128 [ 3259 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.085940 [ 2896 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.184494 [ 3173 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.190665 [ 3279 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.446390 [ 3176 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.446482 [ 3187 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.541300 [ 3172 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.542066 [ 3167 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:31.560222 [ 3212 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.089471 [ 3218 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.187893 [ 3184 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.193906 [ 3206 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.454956 [ 3252 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.455024 [ 3143 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.550643 [ 3215 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.551483 [ 3198 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:32.563921 [ 3242 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.092005 [ 3240 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.191692 [ 3211 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.197766 [ 3205 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.461075 [ 3251 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.462283 [ 3241 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.554433 [ 3236 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.555530 [ 3229 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:33.572185 [ 3265 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.094948 [ 3209 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.194733 [ 3208 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.200866 [ 3272 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.464307 [ 3217 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.466295 [ 3321 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.557843 [ 2978 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.558850 [ 2956 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:34.575938 [ 3274 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.098260 [ 3248 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.198116 [ 3268 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.204434 [ 3329 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.467416 [ 3296 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.470023 [ 3302 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.561295 [ 3308 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.562420 [ 3297 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:35.579475 [ 3298 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.101970 [ 3313 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.202164 [ 3315 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.207459 [ 2826 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.471033 [ 3331 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.473816 [ 3266 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.565214 [ 3287 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.566031 [ 3191 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:36.582965 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.105149 [ 3309 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.205565 [ 2833 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.210587 [ 2856 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.475177 [ 2857 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.477662 [ 3326 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.569717 [ 2849 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.570403 [ 2851 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:37.607812 [ 2872 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.108519 [ 2834 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.209267 [ 2843 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.214131 [ 2985 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.478460 [ 3021 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.480857 [ 3037 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.573546 [ 3038 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.574586 [ 3000 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:38.611612 [ 2877 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.111880 [ 3281 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.212805 [ 2860 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.219089 [ 3335 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.481745 [ 2909 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.483925 [ 2905 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.576959 [ 2894 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.577800 [ 2885 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:39.615424 [ 3035 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.115755 [ 3112 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.216007 [ 2926 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.222066 [ 3001 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.485783 [ 3305 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.487238 [ 3166 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.580812 [ 2836 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.581596 [ 2923 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:40.619001 [ 2904 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.119817 [ 2906 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.218783 [ 2913 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.225119 [ 3275 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.489494 [ 3286 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.491033 [ 2924 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.585187 [ 2907 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.585584 [ 2870 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:41.622555 [ 2899 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.123250 [ 2841 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.221873 [ 2876 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.228527 [ 2889 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.493595 [ 2935 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.494462 [ 2921 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.589115 [ 2946 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.589807 [ 2934 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:42.626026 [ 2948 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.126828 [ 2973 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.225688 [ 2965 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.231860 [ 2961 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.533733 [ 2994 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.534495 [ 2957 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.592171 [ 2929 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.593033 [ 2944 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:43.632342 [ 2960 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.129843 [ 2996 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.229528 [ 3004 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.235638 [ 3062 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.537656 [ 3057 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.539076 [ 3011 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.599942 [ 3026 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.600087 [ 3041 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:44.636630 [ 3036 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.173095 [ 2980 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.233180 [ 3030 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.238897 [ 3064 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.541359 [ 3044 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.543965 [ 3069 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.603877 [ 3018 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.605734 [ 3033 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:45.641598 [ 3013 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.176424 [ 3068 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.236410 [ 3078 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.242383 [ 2990 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.544898 [ 3065 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.547482 [ 3092 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.607844 [ 3098 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.608928 [ 3107 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:46.645173 [ 3039 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.179707 [ 3140 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.240289 [ 3061 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.246185 [ 3055 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.548723 [ 3129 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.551428 [ 3125 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.611446 [ 3104 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.612696 [ 3093 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:47.649039 [ 3108 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.183438 [ 3113 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.243638 [ 3133 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.253397 [ 3096 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.552913 [ 3059 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.555306 [ 3115 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.616393 [ 3148 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.622786 [ 3147 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:48.658018 [ 3084 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.187217 [ 3145 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.247286 [ 3086 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.257281 [ 3154 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.556571 [ 3142 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.559133 [ 3076 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.620058 [ 3180 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.626294 [ 3164 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:49.661713 [ 3179 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.190899 [ 3181 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.250897 [ 3259 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.260914 [ 3178 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.560557 [ 2954 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.562703 [ 2955 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.624042 [ 2925 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.629925 [ 2896 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:50.665432 [ 3149 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.194129 [ 3201 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.253906 [ 3167 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.264026 [ 3212 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.567257 [ 3193 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.574269 [ 3218 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.628270 [ 3130 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.641167 [ 3184 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:51.669301 [ 3206 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.198017 [ 3225 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.266049 [ 3247 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.266884 [ 3234 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.571426 [ 3216 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.578037 [ 3240 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.632068 [ 3260 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.644734 [ 3222 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:52.672680 [ 3211 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.201527 [ 3250 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.269271 [ 3207 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.270045 [ 3236 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.575242 [ 3237 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.581087 [ 3195 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.635786 [ 3196 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.650350 [ 3209 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:53.675829 [ 3233 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.290198 [ 2981 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.291370 [ 3239 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.291970 [ 3280 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.578684 [ 3311 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.584581 [ 3299 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.639392 [ 2956 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.653986 [ 3274 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:54.679282 [ 3243 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.297443 [ 3255 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.297880 [ 3293 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.298543 [ 3320 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.582518 [ 3182 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.588342 [ 3267 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.643541 [ 3302 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.663587 [ 3317 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:55.683246 [ 3308 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.301444 [ 3313 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.302254 [ 3319 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.371217 [ 3315 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.588218 [ 3266 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.603642 [ 3303 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.647327 [ 3191 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.667381 [ 2852 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:56.686975 [ 2850 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.305058 [ 2856 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.306258 [ 2857 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.338101 [ 2833 ] {} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286ca7bc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286cb086 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f2f94fabac3 16. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.374694 [ 2837 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.591503 [ 2830 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.606799 [ 2824 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.651133 [ 2848 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.672392 [ 3332 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:57.691325 [ 2835 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.308844 [ 3037 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.309764 [ 3038 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.378176 [ 2877 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.595034 [ 3034 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.610528 [ 3027 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.655142 [ 3186 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.676320 [ 3281 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:58.695488 [ 2881 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.312518 [ 2902 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.313162 [ 2855 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.381862 [ 3035 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.599182 [ 2869 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.614466 [ 2901 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.659340 [ 2863 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.680026 [ 2908 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:45:59.699421 [ 3228 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.316481 [ 3305 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.317902 [ 3166 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.393926 [ 3199 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.602869 [ 3151 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.618181 [ 3262 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.662636 [ 2884 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.683232 [ 2912 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:00.702779 [ 2913 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.319817 [ 2907 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.321182 [ 2870 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.397973 [ 2899 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.606665 [ 2893 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.621877 [ 2930 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.666107 [ 2952 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.686774 [ 2915 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:01.705976 [ 2903 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.323357 [ 2876 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.324828 [ 2889 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.401571 [ 2932 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.610576 [ 2940 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.640206 [ 2921 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.670101 [ 2892 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.690062 [ 2986 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:02.709326 [ 2939 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.327898 [ 2969 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.329740 [ 2973 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.405228 [ 2937 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.614110 [ 2962 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.643887 [ 2971 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.673803 [ 2994 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.693572 [ 2957 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:03.712424 [ 2982 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.332729 [ 2984 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.333660 [ 2933 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.409775 [ 2963 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.618102 [ 2949 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.648051 [ 2998 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.678124 [ 3040 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.697247 [ 3009 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:04.719345 [ 3004 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.337613 [ 3036 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.338465 [ 3010 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.413657 [ 2975 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.621619 [ 3007 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.651381 [ 2989 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.681738 [ 3031 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.700310 [ 3030 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:05.723273 [ 3064 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.341562 [ 3017 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.342153 [ 3050 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.417833 [ 3054 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.625979 [ 3090 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.655437 [ 3068 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.685512 [ 3005 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.703883 [ 3087 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:06.727420 [ 3105 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.345710 [ 3067 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.346340 [ 3039 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.421658 [ 3102 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.640080 [ 3077 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.659221 [ 3055 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.688623 [ 3094 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.707883 [ 3099 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:07.731621 [ 3126 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.349439 [ 3058 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.350261 [ 3114 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.425395 [ 3072 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.641622 [ 3096 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.660995 [ 3117 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.690177 [ 3128 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.709200 [ 3139 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:08.733764 [ 3241 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.351367 [ 2871 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.351676 [ 3037 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.428151 [ 3038 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.642394 [ 3046 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.661630 [ 3027 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.690971 [ 3281 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.709943 [ 2864 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:09.734624 [ 2853 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.352199 [ 2861 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.352389 [ 2884 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.428883 [ 3122 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.643195 [ 2948 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.662376 [ 2969 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.691532 [ 2937 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.710668 [ 2961 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:10.735728 [ 2977 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.353038 [ 3049 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.353153 [ 3079 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.429657 [ 3067 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.643934 [ 3129 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.663150 [ 3097 ] {} test_6rtahzsf.rename1 (a78c5445-4dae-49b0-bb09-204ffea118dd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.692296 [ 3108 ] {} test_6rtahzsf.rename2 (f79507e9-8157-4f3a-8582-47e0a069c833): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6rtahzsf/rename/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.711395 [ 3125 ] {} test_6wd0bgcu.table_for_synchronous_mutations2 (95d752ff-b008-4ebd-8b29-053ba6a169b0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:11.736492 [ 3113 ] {} test_6wd0bgcu.table_for_synchronous_mutations1 (b2348f4b-3c87-4a58-8b3a-0699c3fdc8a0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_6wd0bgcu/test_01049/table_for_synchronous_mutations/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:12.354049 [ 3232 ] {} test_pgfcbq30.`02863_delayed_source` (ce9d07a9-f26e-478d-90fe-3f3a455182ba): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_pgfcbq30/02863_delayed_source/r1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:12.354133 [ 3170 ] {} test_6w353n2h.data_rep_02228 (7592e7af-a58d-4119-bd62-950c31b924d9): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_6w353n2h/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:12.430150 [ 2955 ] {} test_xixt5dk1.test (358250ed-7b88-4e81-8eb2-c98fb2a47627): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:12.644507 [ 3252 ] {} test_xixt5dk1.test2 (19dfcb38-9120-4286-aa49-c6c70d2ee406): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/test_xixt5dk1/test_01346/table/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabd3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba1a503 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb07971 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f5247 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 11. asan_thread_start(void*) @ 0x000000000aa45059 12. ? @ 0x00007f2f94fabac3 13. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:24.017597 [ 3444 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {694802ad-31e0-4126-a80c-f490a491db20::202510_372_442_14}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:46:50.036866 [ 3436 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c6436924-6aa9-401d-be8b-6811ef6366a4::202510_1_248_87}: 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001adfe1da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfad7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc3ae45 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc3985b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c431fc8 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c433715 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f2f94fabac3 15. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:47:12.811319 [ 24016 ] {148eccb1-b5f4-4b1b-afe5-18b64ed1a782} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.099055273 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:50192) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:47:12.811769 [ 24016 ] {148eccb1-b5f4-4b1b-afe5-18b64ed1a782} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.099055273 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x000000002785b99a 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x000000002785a104 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d359495 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358e20 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*) @ 0x000000002d37c7d7 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 10. asan_thread_start(void*) @ 0x000000000aa45059 11. ? @ 0x00007f2f94fabac3 12. ? @ 0x00007f2f9503d850 2025.10.15 20:47:13.875185 [ 24016 ] {1bc81ce2-973c-4313-94e1-5fe4e04b876c} 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.10521.altinitytest (altinity build)) (from [::1]:46210) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000027d0f995 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x0000000027d0f59b 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000027d0ed19 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192764 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 2025.10.15 20:47:13.876188 [ 24016 ] {1bc81ce2-973c-4313-94e1-5fe4e04b876c} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000027d0f995 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x0000000027d0f59b 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000027d0ed19 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x0000000029192764 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291c8198 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b3cc5c 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&)>) @ 0x0000000029b4369f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d076dd1 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d07dc39 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1dce17 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003453ffef 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x0000000034540bd7 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x00000000344432eb 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000003443d448 17. asan_thread_start(void*) @ 0x000000000aa45059 18. ? @ 0x00007f2f94fabac3 19. ? @ 0x00007f2f9503d850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:47:20.843001 [ 2761 ] {} Application: Closed all listening sockets. Waiting for 17 outstanding connections. 2025.10.15 20:47:25.750326 [ 2761 ] {} Application: Closed connections. But 17 remain. Tip: To increase wait time add to config: 60 2025.10.15 20:47:25.750486 [ 2761 ] {} Application: Will shutdown forcefully. 2025.10.15 20:47:27.628885 [ 24097 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.15 20:47:27.643636 [ 24097 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.15 20:47:27.644532 [ 24097 ] {} 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.15 20:47:27.645183 [ 24097 ] {} 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.15 20:47:28.812752 [ 24097 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.15 20:47:28.823322 [ 24097 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.15 20:47:28.823363 [ 24097 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.15 20:47:28.874614 [ 24686 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.15 20:47:30.823269 [ 24097 ] {} 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.15 20:47:31.405697 [ 24097 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.10.15 20:47:31.407618 [ 24097 ] {} Context: Server has databases (for example `dict_db_01224`) with Ordinary engine, which was deprecated. To convert this database to the new Atomic engine, create a flag /var/lib/clickhouse/flags/convert_ordinary_to_atomic and make sure that ClickHouse has write permission for it. Example: sudo touch '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' && sudo chmod 666 '/var/lib/clickhouse/flags/convert_ordinary_to_atomic' 2025.10.15 20:47:31.544413 [ 24097 ] {} TablesLoader: Tables test_1.distributed depend on default.x, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.15 20:47:31.544705 [ 24097 ] {} TablesLoader: Tables test_01824.t2_distr, test_01824.t1_distr depend on default.id, but seems like that does not exist. Will ignore it and try to load existing tables 2025.10.15 20:47:31.920249 [ 24113 ] {} void DB::StorageBuffer::backgroundFlush(): 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a38ce 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002be5b9bf 8. ./build_docker/./src/Storages/StorageBuffer.cpp:1096: DB::StorageBuffer::backgroundFlush() @ 0x000000002be633af 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271ee190 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f409d 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*) @ 0x00000000271f5247 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 14. asan_thread_start(void*) @ 0x000000000aa45059 15. ? @ 0x00007f80f49e7ac3 16. ? @ 0x00007f80f4a79850 (version 24.8.14.10521.altinitytest (altinity build)) 2025.10.15 20:47:32.437306 [ 24102 ] {c0aa8452-a230-4390-94a1-ca69417b4166} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:53262) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f80f49e7ac3 14. ? @ 0x00007f80f4a79850 2025.10.15 20:47:32.438044 [ 24102 ] {c0aa8452-a230-4390-94a1-ca69417b4166} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f80f49e7ac3 14. ? @ 0x00007f80f4a79850 2025.10.15 20:47:37.694198 [ 24102 ] {2d3e52a7-414e-4f0a-a3d8-e39f1b7e876f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58380) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f80f49e7ac3 15. ? @ 0x00007f80f4a79850 2025.10.15 20:47:37.694743 [ 24102 ] {2d3e52a7-414e-4f0a-a3d8-e39f1b7e876f} 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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af82bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d35aa9b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d35c815 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af80b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8c7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 13. asan_thread_start(void*) @ 0x000000000aa45059 14. ? @ 0x00007f80f49e7ac3 15. ? @ 0x00007f80f4a79850 2025.10.15 20:47:42.972281 [ 24102 ] {7524bbe9-d969-4a99-b567-7f71312f3ce9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10521.altinitytest (altinity build)) (from [::1]:58388) (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) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f80f49e7ac3 14. ? @ 0x00007f80f4a79850 2025.10.15 20:47:42.973030 [ 24102 ] {7524bbe9-d969-4a99-b567-7f71312f3ce9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x0000000034362854 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb22c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa90445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8d157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af83a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af827a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d35c0aa 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d3591c4 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d358d5b 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*) @ 0x000000002d37c7d7 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7bcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af880b5 12. asan_thread_start(void*) @ 0x000000000aa45059 13. ? @ 0x00007f80f49e7ac3 14. ? @ 0x00007f80f4a79850